The following issues were found
src/main/java/io/reactivex/rxjava3/internal/operators/flowable/FlowableThrottleLatest.java
34 issues
Line: 39
*/
public final class FlowableThrottleLatest<T> extends AbstractFlowableWithUpstream<T, T> {
final long timeout;
final TimeUnit unit;
final Scheduler scheduler;
Reported by PMD.
Line: 41
final long timeout;
final TimeUnit unit;
final Scheduler scheduler;
final boolean emitLast;
Reported by PMD.
Line: 43
final TimeUnit unit;
final Scheduler scheduler;
final boolean emitLast;
public FlowableThrottleLatest(Flowable<T> source,
long timeout, TimeUnit unit, Scheduler scheduler,
Reported by PMD.
Line: 45
final Scheduler scheduler;
final boolean emitLast;
public FlowableThrottleLatest(Flowable<T> source,
long timeout, TimeUnit unit, Scheduler scheduler,
boolean emitLast) {
super(source);
Reported by PMD.
Line: 62
source.subscribe(new ThrottleLatestSubscriber<>(s, timeout, unit, scheduler.createWorker(), emitLast));
}
static final class ThrottleLatestSubscriber<T>
extends AtomicInteger
implements FlowableSubscriber<T>, Subscription, Runnable {
private static final long serialVersionUID = -8296689127439125014L;
Reported by PMD.
Line: 62
source.subscribe(new ThrottleLatestSubscriber<>(s, timeout, unit, scheduler.createWorker(), emitLast));
}
static final class ThrottleLatestSubscriber<T>
extends AtomicInteger
implements FlowableSubscriber<T>, Subscription, Runnable {
private static final long serialVersionUID = -8296689127439125014L;
Reported by PMD.
Line: 68
private static final long serialVersionUID = -8296689127439125014L;
final Subscriber<? super T> downstream;
final long timeout;
final TimeUnit unit;
Reported by PMD.
Line: 70
final Subscriber<? super T> downstream;
final long timeout;
final TimeUnit unit;
final Scheduler.Worker worker;
Reported by PMD.
Line: 72
final long timeout;
final TimeUnit unit;
final Scheduler.Worker worker;
final boolean emitLast;
Reported by PMD.
Line: 74
final TimeUnit unit;
final Scheduler.Worker worker;
final boolean emitLast;
final AtomicReference<T> latest;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/flowable/FlowableOnBackpressureBuffer.java
34 issues
Line: 30
import io.reactivex.rxjava3.internal.util.BackpressureHelper;
public final class FlowableOnBackpressureBuffer<T> extends AbstractFlowableWithUpstream<T, T> {
final int bufferSize;
final boolean unbounded;
final boolean delayError;
final Action onOverflow;
public FlowableOnBackpressureBuffer(Flowable<T> source, int bufferSize, boolean unbounded,
Reported by PMD.
Line: 31
public final class FlowableOnBackpressureBuffer<T> extends AbstractFlowableWithUpstream<T, T> {
final int bufferSize;
final boolean unbounded;
final boolean delayError;
final Action onOverflow;
public FlowableOnBackpressureBuffer(Flowable<T> source, int bufferSize, boolean unbounded,
boolean delayError, Action onOverflow) {
Reported by PMD.
Line: 32
public final class FlowableOnBackpressureBuffer<T> extends AbstractFlowableWithUpstream<T, T> {
final int bufferSize;
final boolean unbounded;
final boolean delayError;
final Action onOverflow;
public FlowableOnBackpressureBuffer(Flowable<T> source, int bufferSize, boolean unbounded,
boolean delayError, Action onOverflow) {
super(source);
Reported by PMD.
Line: 33
final int bufferSize;
final boolean unbounded;
final boolean delayError;
final Action onOverflow;
public FlowableOnBackpressureBuffer(Flowable<T> source, int bufferSize, boolean unbounded,
boolean delayError, Action onOverflow) {
super(source);
this.bufferSize = bufferSize;
Reported by PMD.
Line: 49
source.subscribe(new BackpressureBufferSubscriber<>(s, bufferSize, unbounded, delayError, onOverflow));
}
static final class BackpressureBufferSubscriber<T> extends BasicIntQueueSubscription<T> implements FlowableSubscriber<T> {
private static final long serialVersionUID = -2514538129242366402L;
final Subscriber<? super T> downstream;
final SimplePlainQueue<T> queue;
Reported by PMD.
Line: 49
source.subscribe(new BackpressureBufferSubscriber<>(s, bufferSize, unbounded, delayError, onOverflow));
}
static final class BackpressureBufferSubscriber<T> extends BasicIntQueueSubscription<T> implements FlowableSubscriber<T> {
private static final long serialVersionUID = -2514538129242366402L;
final Subscriber<? super T> downstream;
final SimplePlainQueue<T> queue;
Reported by PMD.
Line: 49
source.subscribe(new BackpressureBufferSubscriber<>(s, bufferSize, unbounded, delayError, onOverflow));
}
static final class BackpressureBufferSubscriber<T> extends BasicIntQueueSubscription<T> implements FlowableSubscriber<T> {
private static final long serialVersionUID = -2514538129242366402L;
final Subscriber<? super T> downstream;
final SimplePlainQueue<T> queue;
Reported by PMD.
Line: 53
private static final long serialVersionUID = -2514538129242366402L;
final Subscriber<? super T> downstream;
final SimplePlainQueue<T> queue;
final boolean delayError;
final Action onOverflow;
Subscription upstream;
Reported by PMD.
Line: 54
private static final long serialVersionUID = -2514538129242366402L;
final Subscriber<? super T> downstream;
final SimplePlainQueue<T> queue;
final boolean delayError;
final Action onOverflow;
Subscription upstream;
Reported by PMD.
Line: 55
final Subscriber<? super T> downstream;
final SimplePlainQueue<T> queue;
final boolean delayError;
final Action onOverflow;
Subscription upstream;
volatile boolean cancelled;
Reported by PMD.
src/main/java/io/reactivex/rxjava3/processors/BehaviorProcessor.java
34 issues
Line: 163
* @param <T>
* the type of item expected to be observed and emitted by the Processor
*/
public final class BehaviorProcessor<@NonNull T> extends FlowableProcessor<T> {
final AtomicReference<BehaviorSubscription<T>[]> subscribers;
static final Object[] EMPTY_ARRAY = new Object[0];
@SuppressWarnings("rawtypes")
Reported by PMD.
Line: 163
* @param <T>
* the type of item expected to be observed and emitted by the Processor
*/
public final class BehaviorProcessor<@NonNull T> extends FlowableProcessor<T> {
final AtomicReference<BehaviorSubscription<T>[]> subscribers;
static final Object[] EMPTY_ARRAY = new Object[0];
@SuppressWarnings("rawtypes")
Reported by PMD.
Line: 164
* the type of item expected to be observed and emitted by the Processor
*/
public final class BehaviorProcessor<@NonNull T> extends FlowableProcessor<T> {
final AtomicReference<BehaviorSubscription<T>[]> subscribers;
static final Object[] EMPTY_ARRAY = new Object[0];
@SuppressWarnings("rawtypes")
static final BehaviorSubscription[] EMPTY = new BehaviorSubscription[0];
Reported by PMD.
Line: 174
@SuppressWarnings("rawtypes")
static final BehaviorSubscription[] TERMINATED = new BehaviorSubscription[0];
final ReadWriteLock lock;
final Lock readLock;
final Lock writeLock;
final AtomicReference<Object> value;
Reported by PMD.
Line: 175
static final BehaviorSubscription[] TERMINATED = new BehaviorSubscription[0];
final ReadWriteLock lock;
final Lock readLock;
final Lock writeLock;
final AtomicReference<Object> value;
final AtomicReference<Throwable> terminalEvent;
Reported by PMD.
Line: 176
final ReadWriteLock lock;
final Lock readLock;
final Lock writeLock;
final AtomicReference<Object> value;
final AtomicReference<Throwable> terminalEvent;
Reported by PMD.
Line: 180
final AtomicReference<Object> value;
final AtomicReference<Throwable> terminalEvent;
long index;
/**
* Creates a {@link BehaviorProcessor} without a default item.
Reported by PMD.
Line: 182
final AtomicReference<Throwable> terminalEvent;
long index;
/**
* Creates a {@link BehaviorProcessor} without a default item.
*
* @param <T>
Reported by PMD.
Line: 220
* Constructs an empty BehaviorProcessor.
* @since 2.0
*/
@SuppressWarnings("unchecked")
BehaviorProcessor() {
this.value = new AtomicReference<>();
this.lock = new ReentrantReadWriteLock();
this.readLock = lock.readLock();
this.writeLock = lock.writeLock();
Reported by PMD.
Line: 346
@Override
@CheckReturnValue
public boolean hasSubscribers() {
return subscribers.get().length != 0;
}
@CheckReturnValue
/* test support*/ int subscriberCount() {
return subscribers.get().length;
Reported by PMD.
src/test/java/io/reactivex/rxjava3/internal/operators/single/SingleTimestampTest.java
33 issues
Line: 30
public class SingleTimestampTest {
@Test
public void just() {
Single.just(1)
.timeInterval()
.test()
.assertValueCount(1)
.assertNoErrors()
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timeInterval()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timeInterval()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timeInterval()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timeInterval()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timeInterval()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 40
}
@Test
public void error() {
Single.error(new TestException())
.timeInterval()
.test()
.assertFailure(TestException.class);
}
Reported by PMD.
Line: 48
}
@Test
public void justSeconds() {
Single.just(1)
.timeInterval(TimeUnit.SECONDS)
.test()
.assertValueCount(1)
.assertNoErrors()
Reported by PMD.
Line: 49
@Test
public void justSeconds() {
Single.just(1)
.timeInterval(TimeUnit.SECONDS)
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 49
@Test
public void justSeconds() {
Single.just(1)
.timeInterval(TimeUnit.SECONDS)
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
src/test/java/io/reactivex/rxjava3/internal/util/MiscUtilTest.java
33 issues
Line: 27
import io.reactivex.rxjava3.internal.util.AppendOnlyLinkedArrayList.NonThrowingPredicate;
import io.reactivex.rxjava3.testsupport.TestHelper;
public class MiscUtilTest extends RxJavaTest {
@Test
public void pow2UtilityClass() {
TestHelper.checkUtilityClass(Pow2.class);
}
Reported by PMD.
Line: 29
public class MiscUtilTest extends RxJavaTest {
@Test
public void pow2UtilityClass() {
TestHelper.checkUtilityClass(Pow2.class);
}
@Test
public void isPowerOf2() {
Reported by PMD.
Line: 34
}
@Test
public void isPowerOf2() {
for (int i = 1; i > 0; i *= 2) {
assertTrue(Pow2.isPowerOfTwo(i));
}
assertFalse(Pow2.isPowerOfTwo(3));
Reported by PMD.
Line: 36
@Test
public void isPowerOf2() {
for (int i = 1; i > 0; i *= 2) {
assertTrue(Pow2.isPowerOfTwo(i));
}
assertFalse(Pow2.isPowerOfTwo(3));
assertFalse(Pow2.isPowerOfTwo(5));
assertFalse(Pow2.isPowerOfTwo(6));
Reported by PMD.
Line: 39
assertTrue(Pow2.isPowerOfTwo(i));
}
assertFalse(Pow2.isPowerOfTwo(3));
assertFalse(Pow2.isPowerOfTwo(5));
assertFalse(Pow2.isPowerOfTwo(6));
assertFalse(Pow2.isPowerOfTwo(7));
}
Reported by PMD.
Line: 40
}
assertFalse(Pow2.isPowerOfTwo(3));
assertFalse(Pow2.isPowerOfTwo(5));
assertFalse(Pow2.isPowerOfTwo(6));
assertFalse(Pow2.isPowerOfTwo(7));
}
@Test
Reported by PMD.
Line: 41
assertFalse(Pow2.isPowerOfTwo(3));
assertFalse(Pow2.isPowerOfTwo(5));
assertFalse(Pow2.isPowerOfTwo(6));
assertFalse(Pow2.isPowerOfTwo(7));
}
@Test
public void hashMapSupplier() {
Reported by PMD.
Line: 42
assertFalse(Pow2.isPowerOfTwo(3));
assertFalse(Pow2.isPowerOfTwo(5));
assertFalse(Pow2.isPowerOfTwo(6));
assertFalse(Pow2.isPowerOfTwo(7));
}
@Test
public void hashMapSupplier() {
TestHelper.checkEnum(HashMapSupplier.class);
Reported by PMD.
Line: 46
}
@Test
public void hashMapSupplier() {
TestHelper.checkEnum(HashMapSupplier.class);
}
@Test
public void arrayListSupplier() {
Reported by PMD.
Line: 51
}
@Test
public void arrayListSupplier() {
TestHelper.checkEnum(ArrayListSupplier.class);
}
@Test
public void errorModeEnum() {
Reported by PMD.
src/test/java/io/reactivex/rxjava3/internal/operators/observable/BlockingObservableToFutureTest.java
33 issues
Line: 32
public class BlockingObservableToFutureTest extends RxJavaTest {
@Test
public void toFuture() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one");
Future<String> f = obs.toFuture();
assertEquals("one", f.get());
}
@Test
Reported by PMD.
Line: 33
@Test
public void toFuture() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one");
Future<String> f = obs.toFuture();
assertEquals("one", f.get());
}
@Test
public void toFutureList() throws InterruptedException, ExecutionException {
Reported by PMD.
Line: 34
public void toFuture() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one");
Future<String> f = obs.toFuture();
assertEquals("one", f.get());
}
@Test
public void toFutureList() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one", "two", "three");
Reported by PMD.
Line: 34
public void toFuture() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one");
Future<String> f = obs.toFuture();
assertEquals("one", f.get());
}
@Test
public void toFutureList() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one", "two", "three");
Reported by PMD.
Line: 38
}
@Test
public void toFutureList() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one", "two", "three");
Future<List<String>> f = obs.toList().toFuture();
assertEquals("one", f.get().get(0));
assertEquals("two", f.get().get(1));
assertEquals("three", f.get().get(2));
Reported by PMD.
Line: 40
@Test
public void toFutureList() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one", "two", "three");
Future<List<String>> f = obs.toList().toFuture();
assertEquals("one", f.get().get(0));
assertEquals("two", f.get().get(1));
assertEquals("three", f.get().get(2));
}
Reported by PMD.
Line: 40
@Test
public void toFutureList() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one", "two", "three");
Future<List<String>> f = obs.toList().toFuture();
assertEquals("one", f.get().get(0));
assertEquals("two", f.get().get(1));
assertEquals("three", f.get().get(2));
}
Reported by PMD.
Line: 41
public void toFutureList() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one", "two", "three");
Future<List<String>> f = obs.toList().toFuture();
assertEquals("one", f.get().get(0));
assertEquals("two", f.get().get(1));
assertEquals("three", f.get().get(2));
}
@Test(expected = IndexOutOfBoundsException.class)
Reported by PMD.
Line: 41
public void toFutureList() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one", "two", "three");
Future<List<String>> f = obs.toList().toFuture();
assertEquals("one", f.get().get(0));
assertEquals("two", f.get().get(1));
assertEquals("three", f.get().get(2));
}
@Test(expected = IndexOutOfBoundsException.class)
Reported by PMD.
Line: 41
public void toFutureList() throws InterruptedException, ExecutionException {
Observable<String> obs = Observable.just("one", "two", "three");
Future<List<String>> f = obs.toList().toFuture();
assertEquals("one", f.get().get(0));
assertEquals("two", f.get().get(1));
assertEquals("three", f.get().get(2));
}
@Test(expected = IndexOutOfBoundsException.class)
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/observable/ObservableCache.java
33 issues
Line: 33
/**
* The subscription to the source should happen at most once.
*/
final AtomicBoolean once;
/**
* The number of items per cached nodes.
*/
final int capacityHint;
Reported by PMD.
Line: 38
/**
* The number of items per cached nodes.
*/
final int capacityHint;
/**
* The current known array of observer state to notify.
*/
final AtomicReference<CacheDisposable<T>[]> observers;
Reported by PMD.
Line: 43
/**
* The current known array of observer state to notify.
*/
final AtomicReference<CacheDisposable<T>[]> observers;
/**
* A shared instance of an empty array of observers to avoid creating
* a new empty array when all observers dispose.
*/
Reported by PMD.
Line: 61
/**
* The total number of elements in the list available for reads.
*/
volatile long size;
/**
* The starting point of the cached items.
*/
final Node<T> head;
Reported by PMD.
Line: 66
/**
* The starting point of the cached items.
*/
final Node<T> head;
/**
* The current tail of the linked structure holding the items.
*/
Node<T> tail;
Reported by PMD.
Line: 71
/**
* The current tail of the linked structure holding the items.
*/
Node<T> tail;
/**
* How many items have been put into the tail node so far.
*/
int tailOffset;
Reported by PMD.
Line: 76
/**
* How many items have been put into the tail node so far.
*/
int tailOffset;
/**
* If {@link #observers} is {@link #TERMINATED}, this holds the terminal error if not null.
*/
Throwable error;
Reported by PMD.
Line: 81
/**
* If {@link #observers} is {@link #TERMINATED}, this holds the terminal error if not null.
*/
Throwable error;
/**
* True if the source has terminated.
*/
volatile boolean done;
Reported by PMD.
Line: 86
/**
* True if the source has terminated.
*/
volatile boolean done;
/**
* Constructs an empty, non-connected cache.
* @param source the source to subscribe to for the first incoming observer
* @param capacityHint the number of items expected (reduce allocation frequency)
Reported by PMD.
Line: 93
* @param source the source to subscribe to for the first incoming observer
* @param capacityHint the number of items expected (reduce allocation frequency)
*/
@SuppressWarnings("unchecked")
public ObservableCache(Observable<T> source, int capacityHint) {
super(source);
this.capacityHint = capacityHint;
this.once = new AtomicBoolean();
Node<T> n = new Node<>(capacityHint);
Reported by PMD.
src/test/java/io/reactivex/rxjava3/internal/operators/completable/CompletableDisposeOnTest.java
33 issues
Line: 35
public class CompletableDisposeOnTest extends RxJavaTest {
@Test
public void cancelDelayed() {
TestScheduler scheduler = new TestScheduler();
PublishSubject<Integer> ps = PublishSubject.create();
ps.ignoreElements()
Reported by PMD.
Line: 40
PublishSubject<Integer> ps = PublishSubject.create();
ps.ignoreElements()
.unsubscribeOn(scheduler)
.test()
.dispose();
assertTrue(ps.hasObservers());
Reported by PMD.
Line: 40
PublishSubject<Integer> ps = PublishSubject.create();
ps.ignoreElements()
.unsubscribeOn(scheduler)
.test()
.dispose();
assertTrue(ps.hasObservers());
Reported by PMD.
Line: 40
PublishSubject<Integer> ps = PublishSubject.create();
ps.ignoreElements()
.unsubscribeOn(scheduler)
.test()
.dispose();
assertTrue(ps.hasObservers());
Reported by PMD.
Line: 40
PublishSubject<Integer> ps = PublishSubject.create();
ps.ignoreElements()
.unsubscribeOn(scheduler)
.test()
.dispose();
assertTrue(ps.hasObservers());
Reported by PMD.
Line: 45
.test()
.dispose();
assertTrue(ps.hasObservers());
scheduler.advanceTimeBy(1, TimeUnit.SECONDS);
assertFalse(ps.hasObservers());
}
Reported by PMD.
Line: 45
.test()
.dispose();
assertTrue(ps.hasObservers());
scheduler.advanceTimeBy(1, TimeUnit.SECONDS);
assertFalse(ps.hasObservers());
}
Reported by PMD.
Line: 49
scheduler.advanceTimeBy(1, TimeUnit.SECONDS);
assertFalse(ps.hasObservers());
}
@Test
public void dispose() {
TestHelper.checkDisposed(PublishSubject.create().ignoreElements().unsubscribeOn(new TestScheduler()));
Reported by PMD.
Line: 49
scheduler.advanceTimeBy(1, TimeUnit.SECONDS);
assertFalse(ps.hasObservers());
}
@Test
public void dispose() {
TestHelper.checkDisposed(PublishSubject.create().ignoreElements().unsubscribeOn(new TestScheduler()));
Reported by PMD.
Line: 53
}
@Test
public void dispose() {
TestHelper.checkDisposed(PublishSubject.create().ignoreElements().unsubscribeOn(new TestScheduler()));
}
@Test
public void completeAfterCancel() {
Reported by PMD.
src/main/java/io/reactivex/rxjava3/internal/operators/single/SingleFlatMapIterableFlowable.java
33 issues
Line: 39
*/
public final class SingleFlatMapIterableFlowable<T, R> extends Flowable<R> {
final SingleSource<T> source;
final Function<? super T, ? extends Iterable<? extends R>> mapper;
public SingleFlatMapIterableFlowable(SingleSource<T> source,
Function<? super T, ? extends Iterable<? extends R>> mapper) {
Reported by PMD.
Line: 41
final SingleSource<T> source;
final Function<? super T, ? extends Iterable<? extends R>> mapper;
public SingleFlatMapIterableFlowable(SingleSource<T> source,
Function<? super T, ? extends Iterable<? extends R>> mapper) {
this.source = source;
this.mapper = mapper;
Reported by PMD.
Line: 54
source.subscribe(new FlatMapIterableObserver<>(s, mapper));
}
static final class FlatMapIterableObserver<T, R>
extends BasicIntQueueSubscription<R>
implements SingleObserver<T> {
private static final long serialVersionUID = -8938804753851907758L;
Reported by PMD.
Line: 54
source.subscribe(new FlatMapIterableObserver<>(s, mapper));
}
static final class FlatMapIterableObserver<T, R>
extends BasicIntQueueSubscription<R>
implements SingleObserver<T> {
private static final long serialVersionUID = -8938804753851907758L;
Reported by PMD.
Line: 60
private static final long serialVersionUID = -8938804753851907758L;
final Subscriber<? super R> downstream;
final Function<? super T, ? extends Iterable<? extends R>> mapper;
final AtomicLong requested;
Reported by PMD.
Line: 62
final Subscriber<? super R> downstream;
final Function<? super T, ? extends Iterable<? extends R>> mapper;
final AtomicLong requested;
Disposable upstream;
Reported by PMD.
Line: 64
final Function<? super T, ? extends Iterable<? extends R>> mapper;
final AtomicLong requested;
Disposable upstream;
volatile Iterator<? extends R> it;
Reported by PMD.
Line: 66
final AtomicLong requested;
Disposable upstream;
volatile Iterator<? extends R> it;
volatile boolean cancelled;
Reported by PMD.
Line: 68
Disposable upstream;
volatile Iterator<? extends R> it;
volatile boolean cancelled;
boolean outputFused;
Reported by PMD.
Line: 70
volatile Iterator<? extends R> it;
volatile boolean cancelled;
boolean outputFused;
FlatMapIterableObserver(Subscriber<? super R> actual,
Function<? super T, ? extends Iterable<? extends R>> mapper) {
Reported by PMD.
src/test/java/io/reactivex/rxjava3/internal/operators/single/SingleTimeIntervalTest.java
33 issues
Line: 30
public class SingleTimeIntervalTest {
@Test
public void just() {
Single.just(1)
.timestamp()
.test()
.assertValueCount(1)
.assertNoErrors()
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timestamp()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timestamp()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timestamp()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timestamp()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 31
@Test
public void just() {
Single.just(1)
.timestamp()
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 40
}
@Test
public void error() {
Single.error(new TestException())
.timestamp()
.test()
.assertFailure(TestException.class);
}
Reported by PMD.
Line: 48
}
@Test
public void justSeconds() {
Single.just(1)
.timestamp(TimeUnit.SECONDS)
.test()
.assertValueCount(1)
.assertNoErrors()
Reported by PMD.
Line: 49
@Test
public void justSeconds() {
Single.just(1)
.timestamp(TimeUnit.SECONDS)
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.
Line: 49
@Test
public void justSeconds() {
Single.just(1)
.timestamp(TimeUnit.SECONDS)
.test()
.assertValueCount(1)
.assertNoErrors()
.assertComplete();
Reported by PMD.