The following issues were found
src/main/java/io/reactivex/rxjava3/internal/operators/observable/ObservableRepeatUntil.java
9 issues
Line: 25
import io.reactivex.rxjava3.internal.disposables.SequentialDisposable;
public final class ObservableRepeatUntil<T> extends AbstractObservableWithUpstream<T, T> {
final BooleanSupplier until;
public ObservableRepeatUntil(Observable<T> source, BooleanSupplier until) {
super(source);
this.until = until;
}
Reported by PMD.
Line: 44
private static final long serialVersionUID = -7098360935104053232L;
final Observer<? super T> downstream;
final SequentialDisposable upstream;
final ObservableSource<? extends T> source;
final BooleanSupplier stop;
RepeatUntilObserver(Observer<? super T> actual, BooleanSupplier until, SequentialDisposable sd, ObservableSource<? extends T> source) {
this.downstream = actual;
Reported by PMD.
Line: 45
private static final long serialVersionUID = -7098360935104053232L;
final Observer<? super T> downstream;
final SequentialDisposable upstream;
final ObservableSource<? extends T> source;
final BooleanSupplier stop;
RepeatUntilObserver(Observer<? super T> actual, BooleanSupplier until, SequentialDisposable sd, ObservableSource<? extends T> source) {
this.downstream = actual;
this.upstream = sd;
Reported by PMD.
Line: 46
final Observer<? super T> downstream;
final SequentialDisposable upstream;
final ObservableSource<? extends T> source;
final BooleanSupplier stop;
RepeatUntilObserver(Observer<? super T> actual, BooleanSupplier until, SequentialDisposable sd, ObservableSource<? extends T> source) {
this.downstream = actual;
this.upstream = sd;
this.source = source;
Reported by PMD.
Line: 47
final Observer<? super T> downstream;
final SequentialDisposable upstream;
final ObservableSource<? extends T> source;
final BooleanSupplier stop;
RepeatUntilObserver(Observer<? super T> actual, BooleanSupplier until, SequentialDisposable sd, ObservableSource<? extends T> source) {
this.downstream = actual;
this.upstream = sd;
this.source = source;
this.stop = until;
Reported by PMD.
Line: 75
boolean b;
try {
b = stop.getAsBoolean();
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
downstream.onError(e);
return;
}
if (b) {
Reported by PMD.
Line: 18
import java.util.concurrent.atomic.AtomicInteger;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.disposables.Disposable;
import io.reactivex.rxjava3.exceptions.Exceptions;
import io.reactivex.rxjava3.functions.BooleanSupplier;
import io.reactivex.rxjava3.internal.disposables.SequentialDisposable;
Reported by PMD.
Line: 74
public void onComplete() {
boolean b;
try {
b = stop.getAsBoolean();
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
downstream.onError(e);
return;
}
Reported by PMD.
Line: 92
*/
void subscribeNext() {
if (getAndIncrement() == 0) {
int missed = 1;
for (;;) {
source.subscribe(this);
missed = addAndGet(-missed);
if (missed == 0) {
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/flowable/FlowableDistinct.java
9 issues
Line: 33
public final class FlowableDistinct<T, K> extends AbstractFlowableWithUpstream<T, T> {
final Function<? super T, K> keySelector;
final Supplier<? extends Collection<? super K>> collectionSupplier;
public FlowableDistinct(Flowable<T> source, Function<? super T, K> keySelector, Supplier<? extends Collection<? super K>> collectionSupplier) {
super(source);
Reported by PMD.
Line: 35
final Function<? super T, K> keySelector;
final Supplier<? extends Collection<? super K>> collectionSupplier;
public FlowableDistinct(Flowable<T> source, Function<? super T, K> keySelector, Supplier<? extends Collection<? super K>> collectionSupplier) {
super(source);
this.keySelector = keySelector;
this.collectionSupplier = collectionSupplier;
Reported by PMD.
Line: 49
try {
collection = ExceptionHelper.nullCheck(collectionSupplier.get(), "The collectionSupplier returned a null Collection.");
} catch (Throwable ex) {
Exceptions.throwIfFatal(ex);
EmptySubscription.error(ex, subscriber);
return;
}
Reported by PMD.
Line: 60
static final class DistinctSubscriber<T, K> extends BasicFuseableSubscriber<T, T> {
final Collection<? super K> collection;
final Function<? super T, K> keySelector;
DistinctSubscriber(Subscriber<? super T> actual, Function<? super T, K> keySelector, Collection<? super K> collection) {
super(actual);
Reported by PMD.
Line: 62
final Collection<? super K> collection;
final Function<? super T, K> keySelector;
DistinctSubscriber(Subscriber<? super T> actual, Function<? super T, K> keySelector, Collection<? super K> collection) {
super(actual);
this.keySelector = keySelector;
this.collection = collection;
Reported by PMD.
Line: 82
try {
key = Objects.requireNonNull(keySelector.apply(value), "The keySelector returned a null key");
b = collection.add(key);
} catch (Throwable ex) {
fail(ex);
return;
}
if (b) {
Reported by PMD.
Line: 24
import io.reactivex.rxjava3.annotations.Nullable;
import io.reactivex.rxjava3.core.Flowable;
import io.reactivex.rxjava3.exceptions.Exceptions;
import io.reactivex.rxjava3.functions.*;
import io.reactivex.rxjava3.internal.fuseable.QueueFuseable;
import io.reactivex.rxjava3.internal.subscribers.BasicFuseableSubscriber;
import io.reactivex.rxjava3.internal.subscriptions.EmptySubscription;
import io.reactivex.rxjava3.internal.util.ExceptionHelper;
import io.reactivex.rxjava3.plugins.RxJavaPlugins;
Reported by PMD.
Line: 48
Collection<? super K> collection;
try {
collection = ExceptionHelper.nullCheck(collectionSupplier.get(), "The collectionSupplier returned a null Collection.");
} catch (Throwable ex) {
Exceptions.throwIfFatal(ex);
EmptySubscription.error(ex, subscriber);
return;
}
Reported by PMD.
Line: 81
try {
key = Objects.requireNonNull(keySelector.apply(value), "The keySelector returned a null key");
b = collection.add(key);
} catch (Throwable ex) {
fail(ex);
return;
}
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/flowable/FlowableSingleSingle.java
9 issues
Line: 28
public final class FlowableSingleSingle<T> extends Single<T> implements FuseToFlowable<T> {
final Flowable<T> source;
final T defaultValue;
public FlowableSingleSingle(Flowable<T> source, T defaultValue) {
this.source = source;
Reported by PMD.
Line: 30
final Flowable<T> source;
final T defaultValue;
public FlowableSingleSingle(Flowable<T> source, T defaultValue) {
this.source = source;
this.defaultValue = defaultValue;
}
Reported by PMD.
Line: 50
static final class SingleElementSubscriber<T>
implements FlowableSubscriber<T>, Disposable {
final SingleObserver<? super T> downstream;
final T defaultValue;
Subscription upstream;
Reported by PMD.
Line: 52
final SingleObserver<? super T> downstream;
final T defaultValue;
Subscription upstream;
boolean done;
Reported by PMD.
Line: 54
final T defaultValue;
Subscription upstream;
boolean done;
T value;
Reported by PMD.
Line: 56
Subscription upstream;
boolean done;
T value;
SingleElementSubscriber(SingleObserver<? super T> actual, T defaultValue) {
this.downstream = actual;
Reported by PMD.
Line: 58
boolean done;
T value;
SingleElementSubscriber(SingleObserver<? super T> actual, T defaultValue) {
this.downstream = actual;
this.defaultValue = defaultValue;
}
Reported by PMD.
Line: 108
done = true;
upstream = SubscriptionHelper.CANCELLED;
T v = value;
value = null;
if (v == null) {
v = defaultValue;
}
if (v != null) {
Reported by PMD.
Line: 20
import org.reactivestreams.Subscription;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.disposables.Disposable;
import io.reactivex.rxjava3.internal.fuseable.FuseToFlowable;
import io.reactivex.rxjava3.internal.subscriptions.SubscriptionHelper;
import io.reactivex.rxjava3.plugins.RxJavaPlugins;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/maybe/MaybeDematerialize.java
9 issues
Line: 34
*/
public final class MaybeDematerialize<T, R> extends AbstractMaybeWithUpstream<T, R> {
final Function<? super T, Notification<R>> selector;
public MaybeDematerialize(Maybe<T> source, Function<? super T, Notification<R>> selector) {
super(source);
this.selector = selector;
}
Reported by PMD.
Line: 48
static final class DematerializeObserver<T, R> implements MaybeObserver<T>, Disposable {
final MaybeObserver<? super R> downstream;
final Function<? super T, Notification<R>> selector;
Disposable upstream;
Reported by PMD.
Line: 50
final MaybeObserver<? super R> downstream;
final Function<? super T, Notification<R>> selector;
Disposable upstream;
DematerializeObserver(MaybeObserver<? super R> downstream,
Function<? super T, Notification<R>> selector) {
Reported by PMD.
Line: 52
final Function<? super T, Notification<R>> selector;
Disposable upstream;
DematerializeObserver(MaybeObserver<? super R> downstream,
Function<? super T, Notification<R>> selector) {
this.downstream = downstream;
this.selector = selector;
Reported by PMD.
Line: 84
try {
notification = Objects.requireNonNull(selector.apply(t), "The selector returned a null Notification");
} catch (Throwable ex) {
Exceptions.throwIfFatal(ex);
downstream.onError(ex);
return;
}
if (notification.isOnNext()) {
Reported by PMD.
Line: 89
downstream.onError(ex);
return;
}
if (notification.isOnNext()) {
downstream.onSuccess(notification.getValue());
} else if (notification.isOnComplete()) {
downstream.onComplete();
} else {
downstream.onError(notification.getError());
Reported by PMD.
Line: 91
}
if (notification.isOnNext()) {
downstream.onSuccess(notification.getValue());
} else if (notification.isOnComplete()) {
downstream.onComplete();
} else {
downstream.onError(notification.getError());
}
}
Reported by PMD.
Line: 16
package io.reactivex.rxjava3.internal.operators.maybe;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.disposables.Disposable;
import io.reactivex.rxjava3.exceptions.Exceptions;
import io.reactivex.rxjava3.functions.Function;
import io.reactivex.rxjava3.internal.disposables.DisposableHelper;
Reported by PMD.
Line: 83
Notification<R> notification;
try {
notification = Objects.requireNonNull(selector.apply(t), "The selector returned a null Notification");
} catch (Throwable ex) {
Exceptions.throwIfFatal(ex);
downstream.onError(ex);
return;
}
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/flowable/FlowableSkipWhile.java
9 issues
Line: 24
import io.reactivex.rxjava3.internal.subscriptions.SubscriptionHelper;
public final class FlowableSkipWhile<T> extends AbstractFlowableWithUpstream<T, T> {
final Predicate<? super T> predicate;
public FlowableSkipWhile(Flowable<T> source, Predicate<? super T> predicate) {
super(source);
this.predicate = predicate;
}
Reported by PMD.
Line: 36
}
static final class SkipWhileSubscriber<T> implements FlowableSubscriber<T>, Subscription {
final Subscriber<? super T> downstream;
final Predicate<? super T> predicate;
Subscription upstream;
boolean notSkipping;
SkipWhileSubscriber(Subscriber<? super T> actual, Predicate<? super T> predicate) {
this.downstream = actual;
Reported by PMD.
Line: 37
static final class SkipWhileSubscriber<T> implements FlowableSubscriber<T>, Subscription {
final Subscriber<? super T> downstream;
final Predicate<? super T> predicate;
Subscription upstream;
boolean notSkipping;
SkipWhileSubscriber(Subscriber<? super T> actual, Predicate<? super T> predicate) {
this.downstream = actual;
this.predicate = predicate;
Reported by PMD.
Line: 38
static final class SkipWhileSubscriber<T> implements FlowableSubscriber<T>, Subscription {
final Subscriber<? super T> downstream;
final Predicate<? super T> predicate;
Subscription upstream;
boolean notSkipping;
SkipWhileSubscriber(Subscriber<? super T> actual, Predicate<? super T> predicate) {
this.downstream = actual;
this.predicate = predicate;
}
Reported by PMD.
Line: 39
final Subscriber<? super T> downstream;
final Predicate<? super T> predicate;
Subscription upstream;
boolean notSkipping;
SkipWhileSubscriber(Subscriber<? super T> actual, Predicate<? super T> predicate) {
this.downstream = actual;
this.predicate = predicate;
}
Reported by PMD.
Line: 61
boolean b;
try {
b = predicate.test(t);
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
upstream.cancel();
downstream.onError(e);
return;
}
Reported by PMD.
Line: 16
package io.reactivex.rxjava3.internal.operators.flowable;
import org.reactivestreams.*;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.exceptions.Exceptions;
import io.reactivex.rxjava3.functions.Predicate;
import io.reactivex.rxjava3.internal.subscriptions.SubscriptionHelper;
Reported by PMD.
Line: 18
import org.reactivestreams.*;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.exceptions.Exceptions;
import io.reactivex.rxjava3.functions.Predicate;
import io.reactivex.rxjava3.internal.subscriptions.SubscriptionHelper;
public final class FlowableSkipWhile<T> extends AbstractFlowableWithUpstream<T, T> {
Reported by PMD.
Line: 60
} else {
boolean b;
try {
b = predicate.test(t);
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
upstream.cancel();
downstream.onError(e);
return;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/completable/CompletableMergeArray.java
9 issues
Line: 23
import io.reactivex.rxjava3.plugins.RxJavaPlugins;
public final class CompletableMergeArray extends Completable {
final CompletableSource[] sources;
public CompletableMergeArray(CompletableSource[] sources) {
this.sources = sources;
}
Reported by PMD.
Line: 25
public final class CompletableMergeArray extends Completable {
final CompletableSource[] sources;
public CompletableMergeArray(CompletableSource[] sources) {
this.sources = sources;
}
@Override
public void subscribeActual(final CompletableObserver observer) {
Reported by PMD.
Line: 44
if (c == null) {
set.dispose();
NullPointerException npe = new NullPointerException("A completable source is null");
shared.onError(npe);
return;
}
c.subscribe(shared);
Reported by PMD.
Line: 58
static final class InnerCompletableObserver extends AtomicInteger implements CompletableObserver, Disposable {
private static final long serialVersionUID = -8360547806504310570L;
final CompletableObserver downstream;
final AtomicBoolean once;
final CompositeDisposable set;
Reported by PMD.
Line: 60
final CompletableObserver downstream;
final AtomicBoolean once;
final CompositeDisposable set;
InnerCompletableObserver(CompletableObserver actual, AtomicBoolean once, CompositeDisposable set, int n) {
this.downstream = actual;
Reported by PMD.
Line: 62
final AtomicBoolean once;
final CompositeDisposable set;
InnerCompletableObserver(CompletableObserver actual, AtomicBoolean once, CompositeDisposable set, int n) {
this.downstream = actual;
this.once = once;
this.set = set;
Reported by PMD.
Line: 18
import java.util.concurrent.atomic.*;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.disposables.*;
import io.reactivex.rxjava3.plugins.RxJavaPlugins;
public final class CompletableMergeArray extends Completable {
final CompletableSource[] sources;
Reported by PMD.
Line: 19
import java.util.concurrent.atomic.*;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.disposables.*;
import io.reactivex.rxjava3.plugins.RxJavaPlugins;
public final class CompletableMergeArray extends Completable {
final CompletableSource[] sources;
Reported by PMD.
Line: 25
public final class CompletableMergeArray extends Completable {
final CompletableSource[] sources;
public CompletableMergeArray(CompletableSource[] sources) {
this.sources = sources;
}
@Override
public void subscribeActual(final CompletableObserver observer) {
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/observable/ObservableAllSingle.java
9 issues
Line: 25
import io.reactivex.rxjava3.plugins.RxJavaPlugins;
public final class ObservableAllSingle<T> extends Single<Boolean> implements FuseToObservable<Boolean> {
final ObservableSource<T> source;
final Predicate<? super T> predicate;
public ObservableAllSingle(ObservableSource<T> source, Predicate<? super T> predicate) {
this.source = source;
this.predicate = predicate;
Reported by PMD.
Line: 27
public final class ObservableAllSingle<T> extends Single<Boolean> implements FuseToObservable<Boolean> {
final ObservableSource<T> source;
final Predicate<? super T> predicate;
public ObservableAllSingle(ObservableSource<T> source, Predicate<? super T> predicate) {
this.source = source;
this.predicate = predicate;
}
Reported by PMD.
Line: 44
}
static final class AllObserver<T> implements Observer<T>, Disposable {
final SingleObserver<? super Boolean> downstream;
final Predicate<? super T> predicate;
Disposable upstream;
boolean done;
Reported by PMD.
Line: 45
static final class AllObserver<T> implements Observer<T>, Disposable {
final SingleObserver<? super Boolean> downstream;
final Predicate<? super T> predicate;
Disposable upstream;
boolean done;
Reported by PMD.
Line: 47
final SingleObserver<? super Boolean> downstream;
final Predicate<? super T> predicate;
Disposable upstream;
boolean done;
AllObserver(SingleObserver<? super Boolean> actual, Predicate<? super T> predicate) {
this.downstream = actual;
Reported by PMD.
Line: 49
Disposable upstream;
boolean done;
AllObserver(SingleObserver<? super Boolean> actual, Predicate<? super T> predicate) {
this.downstream = actual;
this.predicate = predicate;
}
Reported by PMD.
Line: 72
boolean b;
try {
b = predicate.test(t);
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
upstream.dispose();
onError(e);
return;
}
Reported by PMD.
Line: 16
package io.reactivex.rxjava3.internal.operators.observable;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.disposables.Disposable;
import io.reactivex.rxjava3.exceptions.Exceptions;
import io.reactivex.rxjava3.functions.Predicate;
import io.reactivex.rxjava3.internal.disposables.DisposableHelper;
import io.reactivex.rxjava3.internal.fuseable.FuseToObservable;
Reported by PMD.
Line: 71
}
boolean b;
try {
b = predicate.test(t);
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
upstream.dispose();
onError(e);
return;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/observable/ObservableDistinctUntilChanged.java
9 issues
Line: 23
public final class ObservableDistinctUntilChanged<T, K> extends AbstractObservableWithUpstream<T, T> {
final Function<? super T, K> keySelector;
final BiPredicate<? super K, ? super K> comparer;
public ObservableDistinctUntilChanged(ObservableSource<T> source, Function<? super T, K> keySelector, BiPredicate<? super K, ? super K> comparer) {
super(source);
Reported by PMD.
Line: 25
final Function<? super T, K> keySelector;
final BiPredicate<? super K, ? super K> comparer;
public ObservableDistinctUntilChanged(ObservableSource<T> source, Function<? super T, K> keySelector, BiPredicate<? super K, ? super K> comparer) {
super(source);
this.keySelector = keySelector;
this.comparer = comparer;
Reported by PMD.
Line: 40
static final class DistinctUntilChangedObserver<T, K> extends BasicFuseableObserver<T, T> {
final Function<? super T, K> keySelector;
final BiPredicate<? super K, ? super K> comparer;
K last;
Reported by PMD.
Line: 42
final Function<? super T, K> keySelector;
final BiPredicate<? super K, ? super K> comparer;
K last;
boolean hasValue;
Reported by PMD.
Line: 44
final BiPredicate<? super K, ? super K> comparer;
K last;
boolean hasValue;
DistinctUntilChangedObserver(Observer<? super T> actual,
Function<? super T, K> keySelector,
Reported by PMD.
Line: 46
K last;
boolean hasValue;
DistinctUntilChangedObserver(Observer<? super T> actual,
Function<? super T, K> keySelector,
BiPredicate<? super K, ? super K> comparer) {
super(actual);
Reported by PMD.
Line: 80
hasValue = true;
last = key;
}
} catch (Throwable ex) {
fail(ex);
return;
}
downstream.onNext(t);
Reported by PMD.
Line: 17
package io.reactivex.rxjava3.internal.operators.observable;
import io.reactivex.rxjava3.annotations.Nullable;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.functions.*;
import io.reactivex.rxjava3.internal.observers.BasicFuseableObserver;
public final class ObservableDistinctUntilChanged<T, K> extends AbstractObservableWithUpstream<T, T> {
Reported by PMD.
Line: 18
import io.reactivex.rxjava3.annotations.Nullable;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.functions.*;
import io.reactivex.rxjava3.internal.observers.BasicFuseableObserver;
public final class ObservableDistinctUntilChanged<T, K> extends AbstractObservableWithUpstream<T, T> {
final Function<? super T, K> keySelector;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/observable/ObservableAnySingle.java
9 issues
Line: 25
import io.reactivex.rxjava3.plugins.RxJavaPlugins;
public final class ObservableAnySingle<T> extends Single<Boolean> implements FuseToObservable<Boolean> {
final ObservableSource<T> source;
final Predicate<? super T> predicate;
public ObservableAnySingle(ObservableSource<T> source, Predicate<? super T> predicate) {
this.source = source;
Reported by PMD.
Line: 27
public final class ObservableAnySingle<T> extends Single<Boolean> implements FuseToObservable<Boolean> {
final ObservableSource<T> source;
final Predicate<? super T> predicate;
public ObservableAnySingle(ObservableSource<T> source, Predicate<? super T> predicate) {
this.source = source;
this.predicate = predicate;
}
Reported by PMD.
Line: 46
static final class AnyObserver<T> implements Observer<T>, Disposable {
final SingleObserver<? super Boolean> downstream;
final Predicate<? super T> predicate;
Disposable upstream;
boolean done;
Reported by PMD.
Line: 47
static final class AnyObserver<T> implements Observer<T>, Disposable {
final SingleObserver<? super Boolean> downstream;
final Predicate<? super T> predicate;
Disposable upstream;
boolean done;
Reported by PMD.
Line: 49
final SingleObserver<? super Boolean> downstream;
final Predicate<? super T> predicate;
Disposable upstream;
boolean done;
AnyObserver(SingleObserver<? super Boolean> actual, Predicate<? super T> predicate) {
this.downstream = actual;
Reported by PMD.
Line: 51
Disposable upstream;
boolean done;
AnyObserver(SingleObserver<? super Boolean> actual, Predicate<? super T> predicate) {
this.downstream = actual;
this.predicate = predicate;
}
Reported by PMD.
Line: 74
boolean b;
try {
b = predicate.test(t);
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
upstream.dispose();
onError(e);
return;
}
Reported by PMD.
Line: 16
package io.reactivex.rxjava3.internal.operators.observable;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.disposables.Disposable;
import io.reactivex.rxjava3.exceptions.Exceptions;
import io.reactivex.rxjava3.functions.Predicate;
import io.reactivex.rxjava3.internal.disposables.DisposableHelper;
import io.reactivex.rxjava3.internal.fuseable.FuseToObservable;
Reported by PMD.
Line: 73
}
boolean b;
try {
b = predicate.test(t);
} catch (Throwable e) {
Exceptions.throwIfFatal(e);
upstream.dispose();
onError(e);
return;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/flowable/FlowableTakeUntil.java
9 issues
Line: 25
import io.reactivex.rxjava3.internal.util.*;
public final class FlowableTakeUntil<T, U> extends AbstractFlowableWithUpstream<T, T> {
final Publisher<? extends U> other;
public FlowableTakeUntil(Flowable<T> source, Publisher<? extends U> other) {
super(source);
this.other = other;
}
Reported by PMD.
Line: 45
private static final long serialVersionUID = -4945480365982832967L;
final Subscriber<? super T> downstream;
final AtomicLong requested;
final AtomicReference<Subscription> upstream;
Reported by PMD.
Line: 47
final Subscriber<? super T> downstream;
final AtomicLong requested;
final AtomicReference<Subscription> upstream;
final AtomicThrowable error;
Reported by PMD.
Line: 49
final AtomicLong requested;
final AtomicReference<Subscription> upstream;
final AtomicThrowable error;
final OtherSubscriber other;
Reported by PMD.
Line: 51
final AtomicReference<Subscription> upstream;
final AtomicThrowable error;
final OtherSubscriber other;
TakeUntilMainSubscriber(Subscriber<? super T> downstream) {
this.downstream = downstream;
Reported by PMD.
Line: 53
final AtomicThrowable error;
final OtherSubscriber other;
TakeUntilMainSubscriber(Subscriber<? super T> downstream) {
this.downstream = downstream;
this.requested = new AtomicLong();
this.upstream = new AtomicReference<>();
Reported by PMD.
Line: 18
import java.util.concurrent.atomic.*;
import org.reactivestreams.*;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.internal.subscriptions.SubscriptionHelper;
import io.reactivex.rxjava3.internal.util.*;
Reported by PMD.
Line: 20
import org.reactivestreams.*;
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.internal.subscriptions.SubscriptionHelper;
import io.reactivex.rxjava3.internal.util.*;
public final class FlowableTakeUntil<T, U> extends AbstractFlowableWithUpstream<T, T> {
final Publisher<? extends U> other;
Reported by PMD.
Line: 22
import io.reactivex.rxjava3.core.*;
import io.reactivex.rxjava3.internal.subscriptions.SubscriptionHelper;
import io.reactivex.rxjava3.internal.util.*;
public final class FlowableTakeUntil<T, U> extends AbstractFlowableWithUpstream<T, T> {
final Publisher<? extends U> other;
public FlowableTakeUntil(Flowable<T> source, Publisher<? extends U> other) {
super(source);
Reported by PMD.