The following issues were found
src/main/java/io/reactivex/rxjava3/internal/operators/parallel/ParallelCollect.java
16 issues
Line: 49
}
@Override
public void subscribe(Subscriber<? super C>[] subscribers) {
subscribers = RxJavaPlugins.onSubscribe(this, subscribers);
if (!validate(subscribers)) {
return;
}
Reported by PMD.
Line: 35
*/
public final class ParallelCollect<T, C> extends ParallelFlowable<C> {
final ParallelFlowable<? extends T> source;
final Supplier<? extends C> initialCollection;
final BiConsumer<? super C, ? super T> collector;
Reported by PMD.
Line: 37
final ParallelFlowable<? extends T> source;
final Supplier<? extends C> initialCollection;
final BiConsumer<? super C, ? super T> collector;
public ParallelCollect(ParallelFlowable<? extends T> source,
Supplier<? extends C> initialCollection, BiConsumer<? super C, ? super T> collector) {
Reported by PMD.
Line: 39
final Supplier<? extends C> initialCollection;
final BiConsumer<? super C, ? super T> collector;
public ParallelCollect(ParallelFlowable<? extends T> source,
Supplier<? extends C> initialCollection, BiConsumer<? super C, ? super T> collector) {
this.source = source;
this.initialCollection = initialCollection;
Reported by PMD.
Line: 66
try {
initialValue = Objects.requireNonNull(initialCollection.get(), "The initialSupplier returned a null value");
} catch (Throwable ex) {
Exceptions.throwIfFatal(ex);
reportError(subscribers, ex);
return;
}
Reported by PMD.
Line: 93
private static final long serialVersionUID = -4767392946044436228L;
final BiConsumer<? super C, ? super T> collector;
C collection;
boolean done;
Reported by PMD.
Line: 95
final BiConsumer<? super C, ? super T> collector;
C collection;
boolean done;
ParallelCollectSubscriber(Subscriber<? super C> subscriber,
C initialValue, BiConsumer<? super C, ? super T> collector) {
Reported by PMD.
Line: 97
C collection;
boolean done;
ParallelCollectSubscriber(Subscriber<? super C> subscriber,
C initialValue, BiConsumer<? super C, ? super T> collector) {
super(subscriber);
this.collection = initialValue;
Reported by PMD.
Line: 125
try {
collector.accept(collection, t);
} catch (Throwable ex) {
Exceptions.throwIfFatal(ex);
cancel();
onError(ex);
}
}
Reported by PMD.
Line: 139
return;
}
done = true;
collection = null;
downstream.onError(t);
}
@Override
public void onComplete() {
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/mixed/ObservableSwitchMapCompletable.java
16 issues
Line: 37
*/
public final class ObservableSwitchMapCompletable<T> extends Completable {
final Observable<T> source;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
Reported by PMD.
Line: 39
final Observable<T> source;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
public ObservableSwitchMapCompletable(Observable<T> source,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) {
Reported by PMD.
Line: 41
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
public ObservableSwitchMapCompletable(Observable<T> source,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) {
this.source = source;
this.mapper = mapper;
Reported by PMD.
Line: 59
static final class SwitchMapCompletableObserver<T> implements Observer<T>, Disposable {
final CompletableObserver downstream;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
Reported by PMD.
Line: 61
final CompletableObserver downstream;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
final AtomicThrowable errors;
Reported by PMD.
Line: 63
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
final AtomicThrowable errors;
final AtomicReference<SwitchMapInnerObserver> inner;
Reported by PMD.
Line: 65
final boolean delayErrors;
final AtomicThrowable errors;
final AtomicReference<SwitchMapInnerObserver> inner;
static final SwitchMapInnerObserver INNER_DISPOSED = new SwitchMapInnerObserver(null);
Reported by PMD.
Line: 67
final AtomicThrowable errors;
final AtomicReference<SwitchMapInnerObserver> inner;
static final SwitchMapInnerObserver INNER_DISPOSED = new SwitchMapInnerObserver(null);
volatile boolean done;
Reported by PMD.
Line: 71
static final SwitchMapInnerObserver INNER_DISPOSED = new SwitchMapInnerObserver(null);
volatile boolean done;
Disposable upstream;
SwitchMapCompletableObserver(CompletableObserver downstream,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) {
Reported by PMD.
Line: 73
volatile boolean done;
Disposable upstream;
SwitchMapCompletableObserver(CompletableObserver downstream,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) {
this.downstream = downstream;
this.mapper = mapper;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/subscribers/LambdaSubscriber.java
16 issues
Line: 33
implements FlowableSubscriber<T>, Subscription, Disposable, LambdaConsumerIntrospection {
private static final long serialVersionUID = -7251123623727029452L;
final Consumer<? super T> onNext;
final Consumer<? super Throwable> onError;
final Action onComplete;
final Consumer<? super Subscription> onSubscribe;
public LambdaSubscriber(Consumer<? super T> onNext, Consumer<? super Throwable> onError,
Reported by PMD.
Line: 33
implements FlowableSubscriber<T>, Subscription, Disposable, LambdaConsumerIntrospection {
private static final long serialVersionUID = -7251123623727029452L;
final Consumer<? super T> onNext;
final Consumer<? super Throwable> onError;
final Action onComplete;
final Consumer<? super Subscription> onSubscribe;
public LambdaSubscriber(Consumer<? super T> onNext, Consumer<? super Throwable> onError,
Reported by PMD.
Line: 34
private static final long serialVersionUID = -7251123623727029452L;
final Consumer<? super T> onNext;
final Consumer<? super Throwable> onError;
final Action onComplete;
final Consumer<? super Subscription> onSubscribe;
public LambdaSubscriber(Consumer<? super T> onNext, Consumer<? super Throwable> onError,
Action onComplete,
Reported by PMD.
Line: 34
private static final long serialVersionUID = -7251123623727029452L;
final Consumer<? super T> onNext;
final Consumer<? super Throwable> onError;
final Action onComplete;
final Consumer<? super Subscription> onSubscribe;
public LambdaSubscriber(Consumer<? super T> onNext, Consumer<? super Throwable> onError,
Action onComplete,
Reported by PMD.
Line: 35
private static final long serialVersionUID = -7251123623727029452L;
final Consumer<? super T> onNext;
final Consumer<? super Throwable> onError;
final Action onComplete;
final Consumer<? super Subscription> onSubscribe;
public LambdaSubscriber(Consumer<? super T> onNext, Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super Subscription> onSubscribe) {
Reported by PMD.
Line: 35
private static final long serialVersionUID = -7251123623727029452L;
final Consumer<? super T> onNext;
final Consumer<? super Throwable> onError;
final Action onComplete;
final Consumer<? super Subscription> onSubscribe;
public LambdaSubscriber(Consumer<? super T> onNext, Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super Subscription> onSubscribe) {
Reported by PMD.
Line: 36
final Consumer<? super T> onNext;
final Consumer<? super Throwable> onError;
final Action onComplete;
final Consumer<? super Subscription> onSubscribe;
public LambdaSubscriber(Consumer<? super T> onNext, Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super Subscription> onSubscribe) {
super();
Reported by PMD.
Line: 36
final Consumer<? super T> onNext;
final Consumer<? super Throwable> onError;
final Action onComplete;
final Consumer<? super Subscription> onSubscribe;
public LambdaSubscriber(Consumer<? super T> onNext, Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super Subscription> onSubscribe) {
super();
Reported by PMD.
Line: 53
if (SubscriptionHelper.setOnce(this, s)) {
try {
onSubscribe.accept(this);
} catch (Throwable ex) {
Exceptions.throwIfFatal(ex);
s.cancel();
onError(ex);
}
}
Reported by PMD.
Line: 66
if (!isDisposed()) {
try {
onNext.accept(t);
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
get().cancel();
onError(e);
}
}
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/subscriptions/DeferredScalarSubscription.java
16 issues
Line: 41
private static final long serialVersionUID = -2151279923272604993L;
/** The Subscriber to emit the value to. */
protected final Subscriber<? super T> downstream;
/** The value is stored here if there is no request yet or in fusion mode. */
protected T value;
/** Indicates this Subscription has no value and not requested yet. */
Reported by PMD.
Line: 44
protected final Subscriber<? super T> downstream;
/** The value is stored here if there is no request yet or in fusion mode. */
protected T value;
/** Indicates this Subscription has no value and not requested yet. */
static final int NO_REQUEST_NO_VALUE = 0;
/** Indicates this Subscription has a value but not requested yet. */
static final int NO_REQUEST_HAS_VALUE = 1;
Reported by PMD.
Line: 84
return;
}
if (state == NO_REQUEST_HAS_VALUE) {
if (compareAndSet(NO_REQUEST_HAS_VALUE, HAS_REQUEST_HAS_VALUE)) {
T v = value;
if (v != null) {
value = null;
Subscriber<? super T> a = downstream;
a.onNext(v);
Reported by PMD.
Line: 87
if (compareAndSet(NO_REQUEST_HAS_VALUE, HAS_REQUEST_HAS_VALUE)) {
T v = value;
if (v != null) {
value = null;
Subscriber<? super T> a = downstream;
a.onNext(v);
if (get() != CANCELLED) {
a.onComplete();
}
Reported by PMD.
Line: 89
if (v != null) {
value = null;
Subscriber<? super T> a = downstream;
a.onNext(v);
if (get() != CANCELLED) {
a.onComplete();
}
}
}
Reported by PMD.
Line: 91
Subscriber<? super T> a = downstream;
a.onNext(v);
if (get() != CANCELLED) {
a.onComplete();
}
}
}
return;
}
Reported by PMD.
Line: 118
lazySet(FUSED_READY);
Subscriber<? super T> a = downstream;
a.onNext(null);
if (get() != CANCELLED) {
a.onComplete();
}
return;
}
Reported by PMD.
Line: 120
Subscriber<? super T> a = downstream;
a.onNext(null);
if (get() != CANCELLED) {
a.onComplete();
}
return;
}
// if state is >= CANCELLED or bit zero is set (*_HAS_VALUE) case, return
Reported by PMD.
Line: 133
if (state == HAS_REQUEST_NO_VALUE) {
lazySet(HAS_REQUEST_HAS_VALUE);
Subscriber<? super T> a = downstream;
a.onNext(v);
if (get() != CANCELLED) {
a.onComplete();
}
return;
}
Reported by PMD.
Line: 135
Subscriber<? super T> a = downstream;
a.onNext(v);
if (get() != CANCELLED) {
a.onComplete();
}
return;
}
value = v;
if (compareAndSet(NO_REQUEST_NO_VALUE, NO_REQUEST_HAS_VALUE)) {
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/mixed/FlowableSwitchMapCompletable.java
16 issues
Line: 40
*/
public final class FlowableSwitchMapCompletable<T> extends Completable {
final Flowable<T> source;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
Reported by PMD.
Line: 42
final Flowable<T> source;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
public FlowableSwitchMapCompletable(Flowable<T> source,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) {
Reported by PMD.
Line: 44
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
public FlowableSwitchMapCompletable(Flowable<T> source,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) {
this.source = source;
this.mapper = mapper;
Reported by PMD.
Line: 60
static final class SwitchMapCompletableObserver<T> implements FlowableSubscriber<T>, Disposable {
final CompletableObserver downstream;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
Reported by PMD.
Line: 62
final CompletableObserver downstream;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
final AtomicThrowable errors;
Reported by PMD.
Line: 64
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
final AtomicThrowable errors;
final AtomicReference<SwitchMapInnerObserver> inner;
Reported by PMD.
Line: 66
final boolean delayErrors;
final AtomicThrowable errors;
final AtomicReference<SwitchMapInnerObserver> inner;
static final SwitchMapInnerObserver INNER_DISPOSED = new SwitchMapInnerObserver(null);
Reported by PMD.
Line: 68
final AtomicThrowable errors;
final AtomicReference<SwitchMapInnerObserver> inner;
static final SwitchMapInnerObserver INNER_DISPOSED = new SwitchMapInnerObserver(null);
volatile boolean done;
Reported by PMD.
Line: 72
static final SwitchMapInnerObserver INNER_DISPOSED = new SwitchMapInnerObserver(null);
volatile boolean done;
Subscription upstream;
SwitchMapCompletableObserver(CompletableObserver downstream,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) {
Reported by PMD.
Line: 74
volatile boolean done;
Subscription upstream;
SwitchMapCompletableObserver(CompletableObserver downstream,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) {
this.downstream = downstream;
this.mapper = mapper;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/flowable/FlowableFlatMapCompletableCompletable.java
16 issues
Line: 37
*/
public final class FlowableFlatMapCompletableCompletable<T> extends Completable implements FuseToFlowable<T> {
final Flowable<T> source;
final Function<? super T, ? extends CompletableSource> mapper;
final int maxConcurrency;
Reported by PMD.
Line: 39
final Flowable<T> source;
final Function<? super T, ? extends CompletableSource> mapper;
final int maxConcurrency;
final boolean delayErrors;
Reported by PMD.
Line: 41
final Function<? super T, ? extends CompletableSource> mapper;
final int maxConcurrency;
final boolean delayErrors;
public FlowableFlatMapCompletableCompletable(Flowable<T> source,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors,
Reported by PMD.
Line: 43
final int maxConcurrency;
final boolean delayErrors;
public FlowableFlatMapCompletableCompletable(Flowable<T> source,
Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors,
int maxConcurrency) {
this.source = source;
Reported by PMD.
Line: 68
implements FlowableSubscriber<T>, Disposable {
private static final long serialVersionUID = 8443155186132538303L;
final CompletableObserver downstream;
final AtomicThrowable errors;
final Function<? super T, ? extends CompletableSource> mapper;
Reported by PMD.
Line: 70
final CompletableObserver downstream;
final AtomicThrowable errors;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
Reported by PMD.
Line: 72
final AtomicThrowable errors;
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
final CompositeDisposable set;
Reported by PMD.
Line: 74
final Function<? super T, ? extends CompletableSource> mapper;
final boolean delayErrors;
final CompositeDisposable set;
final int maxConcurrency;
Reported by PMD.
Line: 76
final boolean delayErrors;
final CompositeDisposable set;
final int maxConcurrency;
Subscription upstream;
Reported by PMD.
Line: 78
final CompositeDisposable set;
final int maxConcurrency;
Subscription upstream;
volatile boolean disposed;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/flowable/BlockingFlowableLatest.java
16 issues
Line: 34
*/
public final class BlockingFlowableLatest<T> implements Iterable<T> {
final Publisher<? extends T> source;
public BlockingFlowableLatest(Publisher<? extends T> source) {
this.source = source;
}
Reported by PMD.
Line: 43
@Override
public Iterator<T> iterator() {
LatestSubscriberIterator<T> lio = new LatestSubscriberIterator<>();
Flowable.<T>fromPublisher(source).materialize().subscribe(lio);
return lio;
}
/** Subscriber of source, iterator for output. */
static final class LatestSubscriberIterator<T> extends DisposableSubscriber<Notification<T>> implements Iterator<T> {
Reported by PMD.
Line: 43
@Override
public Iterator<T> iterator() {
LatestSubscriberIterator<T> lio = new LatestSubscriberIterator<>();
Flowable.<T>fromPublisher(source).materialize().subscribe(lio);
return lio;
}
/** Subscriber of source, iterator for output. */
static final class LatestSubscriberIterator<T> extends DisposableSubscriber<Notification<T>> implements Iterator<T> {
Reported by PMD.
Line: 43
@Override
public Iterator<T> iterator() {
LatestSubscriberIterator<T> lio = new LatestSubscriberIterator<>();
Flowable.<T>fromPublisher(source).materialize().subscribe(lio);
return lio;
}
/** Subscriber of source, iterator for output. */
static final class LatestSubscriberIterator<T> extends DisposableSubscriber<Notification<T>> implements Iterator<T> {
Reported by PMD.
Line: 49
/** Subscriber of source, iterator for output. */
static final class LatestSubscriberIterator<T> extends DisposableSubscriber<Notification<T>> implements Iterator<T> {
final Semaphore notify = new Semaphore(0);
// observer's notification
final AtomicReference<Notification<T>> value = new AtomicReference<>();
// iterator's notification
Notification<T> iteratorNotification;
Reported by PMD.
Line: 51
static final class LatestSubscriberIterator<T> extends DisposableSubscriber<Notification<T>> implements Iterator<T> {
final Semaphore notify = new Semaphore(0);
// observer's notification
final AtomicReference<Notification<T>> value = new AtomicReference<>();
// iterator's notification
Notification<T> iteratorNotification;
@Override
Reported by PMD.
Line: 54
final AtomicReference<Notification<T>> value = new AtomicReference<>();
// iterator's notification
Notification<T> iteratorNotification;
@Override
public void onNext(Notification<T> args) {
boolean wasNotAvailable = value.getAndSet(args) == null;
if (wasNotAvailable) {
Reported by PMD.
Line: 75
}
@Override
public boolean hasNext() {
if (iteratorNotification != null && iteratorNotification.isOnError()) {
throw ExceptionHelper.wrapOrThrow(iteratorNotification.getError());
}
if (iteratorNotification == null || iteratorNotification.isOnNext()) {
if (iteratorNotification == null) {
Reported by PMD.
Line: 80
throw ExceptionHelper.wrapOrThrow(iteratorNotification.getError());
}
if (iteratorNotification == null || iteratorNotification.isOnNext()) {
if (iteratorNotification == null) {
try {
BlockingHelper.verifyNonBlocking();
notify.acquire();
} catch (InterruptedException ex) {
dispose();
Reported by PMD.
Line: 92
Notification<T> n = value.getAndSet(null);
iteratorNotification = n;
if (n.isOnError()) {
throw ExceptionHelper.wrapOrThrow(n.getError());
}
}
}
return iteratorNotification.isOnNext();
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/observers/QueueDrainObserver.java
16 issues
Line: 32
* @param <V> the value type the child subscriber accepts
*/
public abstract class QueueDrainObserver<T, U, V> extends QueueDrainSubscriberPad2 implements Observer<T>, ObservableQueueDrain<U, V> {
protected final Observer<? super V> downstream;
protected final SimplePlainQueue<U> queue;
protected volatile boolean cancelled;
protected volatile boolean done;
Reported by PMD.
Line: 33
*/
public abstract class QueueDrainObserver<T, U, V> extends QueueDrainSubscriberPad2 implements Observer<T>, ObservableQueueDrain<U, V> {
protected final Observer<? super V> downstream;
protected final SimplePlainQueue<U> queue;
protected volatile boolean cancelled;
protected volatile boolean done;
protected Throwable error;
Reported by PMD.
Line: 35
protected final Observer<? super V> downstream;
protected final SimplePlainQueue<U> queue;
protected volatile boolean cancelled;
protected volatile boolean done;
protected Throwable error;
public QueueDrainObserver(Observer<? super V> actual, SimplePlainQueue<U> queue) {
Reported by PMD.
Line: 35
protected final Observer<? super V> downstream;
protected final SimplePlainQueue<U> queue;
protected volatile boolean cancelled;
protected volatile boolean done;
protected Throwable error;
public QueueDrainObserver(Observer<? super V> actual, SimplePlainQueue<U> queue) {
Reported by PMD.
Line: 37
protected volatile boolean cancelled;
protected volatile boolean done;
protected Throwable error;
public QueueDrainObserver(Observer<? super V> actual, SimplePlainQueue<U> queue) {
this.downstream = actual;
this.queue = queue;
Reported by PMD.
Line: 37
protected volatile boolean cancelled;
protected volatile boolean done;
protected Throwable error;
public QueueDrainObserver(Observer<? super V> actual, SimplePlainQueue<U> queue) {
this.downstream = actual;
this.queue = queue;
Reported by PMD.
Line: 38
protected volatile boolean cancelled;
protected volatile boolean done;
protected Throwable error;
public QueueDrainObserver(Observer<? super V> actual, SimplePlainQueue<U> queue) {
this.downstream = actual;
this.queue = queue;
}
Reported by PMD.
Line: 38
protected volatile boolean cancelled;
protected volatile boolean done;
protected Throwable error;
public QueueDrainObserver(Observer<? super V> actual, SimplePlainQueue<U> queue) {
this.downstream = actual;
this.queue = queue;
}
Reported by PMD.
Line: 21
import io.reactivex.rxjava3.core.Observer;
import io.reactivex.rxjava3.disposables.Disposable;
import io.reactivex.rxjava3.internal.fuseable.SimplePlainQueue;
import io.reactivex.rxjava3.internal.util.*;
/**
* Abstract base class for subscribers that hold another subscriber, a queue
* and requires queue-drain behavior.
*
Reported by PMD.
Line: 128
/** Pads the header away from other fields. */
class QueueDrainSubscriberPad0 {
volatile long p1, p2, p3, p4, p5, p6, p7;
volatile long p8, p9, p10, p11, p12, p13, p14, p15;
}
/** The wip counter. */
class QueueDrainSubscriberWip extends QueueDrainSubscriberPad0 {
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/jdk8/FlowableMapOptional.java
16 issues
Line: 33
*/
public final class FlowableMapOptional<T, R> extends Flowable<R> {
final Flowable<T> source;
final Function<? super T, Optional<? extends R>> mapper;
public FlowableMapOptional(Flowable<T> source, Function<? super T, Optional<? extends R>> mapper) {
this.source = source;
Reported by PMD.
Line: 35
final Flowable<T> source;
final Function<? super T, Optional<? extends R>> mapper;
public FlowableMapOptional(Flowable<T> source, Function<? super T, Optional<? extends R>> mapper) {
this.source = source;
this.mapper = mapper;
}
Reported by PMD.
Line: 54
static final class MapOptionalSubscriber<T, R> extends BasicFuseableSubscriber<T, R>
implements ConditionalSubscriber<T> {
final Function<? super T, Optional<? extends R>> mapper;
MapOptionalSubscriber(Subscriber<? super R> downstream, Function<? super T, Optional<? extends R>> mapper) {
super(downstream);
this.mapper = mapper;
}
Reported by PMD.
Line: 81
Optional<? extends R> result;
try {
result = Objects.requireNonNull(mapper.apply(t), "The mapper returned a null Optional");
} catch (Throwable ex) {
fail(ex);
return true;
}
Reported by PMD.
Line: 82
Optional<? extends R> result;
try {
result = Objects.requireNonNull(mapper.apply(t), "The mapper returned a null Optional");
} catch (Throwable ex) {
fail(ex);
return true;
}
if (result.isPresent()) {
Reported by PMD.
Line: 87
return true;
}
if (result.isPresent()) {
downstream.onNext(result.get());
return true;
}
return false;
}
Reported by PMD.
Line: 107
return null;
}
Optional<? extends R> result = Objects.requireNonNull(mapper.apply(item), "The mapper returned a null Optional");
if (result.isPresent()) {
return result.get();
}
if (sourceMode == ASYNC) {
qs.request(1);
}
Reported by PMD.
Line: 108
}
Optional<? extends R> result = Objects.requireNonNull(mapper.apply(item), "The mapper returned a null Optional");
if (result.isPresent()) {
return result.get();
}
if (sourceMode == ASYNC) {
qs.request(1);
}
}
Reported by PMD.
Line: 119
static final class MapOptionalConditionalSubscriber<T, R> extends BasicFuseableConditionalSubscriber<T, R> {
final Function<? super T, Optional<? extends R>> mapper;
MapOptionalConditionalSubscriber(ConditionalSubscriber<? super R> downstream, Function<? super T, Optional<? extends R>> mapper) {
super(downstream);
this.mapper = mapper;
}
Reported by PMD.
Line: 147
Optional<? extends R> result;
try {
result = Objects.requireNonNull(mapper.apply(t), "The mapper returned a null Optional");
} catch (Throwable ex) {
fail(ex);
return true;
}
if (result.isPresent()) {
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/single/SingleTimeout.java
16 issues
Line: 28
public final class SingleTimeout<T> extends Single<T> {
final SingleSource<T> source;
final long timeout;
final TimeUnit unit;
Reported by PMD.
Line: 30
final SingleSource<T> source;
final long timeout;
final TimeUnit unit;
final Scheduler scheduler;
Reported by PMD.
Line: 32
final long timeout;
final TimeUnit unit;
final Scheduler scheduler;
final SingleSource<? extends T> other;
Reported by PMD.
Line: 34
final TimeUnit unit;
final Scheduler scheduler;
final SingleSource<? extends T> other;
public SingleTimeout(SingleSource<T> source, long timeout, TimeUnit unit, Scheduler scheduler,
SingleSource<? extends T> other) {
Reported by PMD.
Line: 36
final Scheduler scheduler;
final SingleSource<? extends T> other;
public SingleTimeout(SingleSource<T> source, long timeout, TimeUnit unit, Scheduler scheduler,
SingleSource<? extends T> other) {
this.source = source;
this.timeout = timeout;
Reported by PMD.
Line: 63
private static final long serialVersionUID = 37497744973048446L;
final SingleObserver<? super T> downstream;
final AtomicReference<Disposable> task;
final TimeoutFallbackObserver<T> fallback;
Reported by PMD.
Line: 65
final SingleObserver<? super T> downstream;
final AtomicReference<Disposable> task;
final TimeoutFallbackObserver<T> fallback;
SingleSource<? extends T> other;
Reported by PMD.
Line: 67
final AtomicReference<Disposable> task;
final TimeoutFallbackObserver<T> fallback;
SingleSource<? extends T> other;
final long timeout;
Reported by PMD.
Line: 69
final TimeoutFallbackObserver<T> fallback;
SingleSource<? extends T> other;
final long timeout;
final TimeUnit unit;
Reported by PMD.
Line: 71
SingleSource<? extends T> other;
final long timeout;
final TimeUnit unit;
static final class TimeoutFallbackObserver<T> extends AtomicReference<Disposable>
implements SingleObserver<T> {
Reported by PMD.