Uses of Interface
io.reactivex.rxjava3.operators.SimpleQueue
-
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.disposables
Classes in io.reactivex.rxjava3.internal.disposables that implement SimpleQueue Modifier and Type Class Description class
EmptyDisposable
Represents a stateless empty Disposable that reports being always empty and disposed. -
Uses of SimpleQueue in io.reactivex.rxjava3.internal.fuseable
Classes in io.reactivex.rxjava3.internal.fuseable that implement SimpleQueue Modifier and Type Class Description class
AbstractEmptyQueueFuseable<T>
Represents an empty, async-onlyQueueFuseable
instance.class
CancellableQueueFuseable<T>
Represents an empty, async-onlyQueueFuseable
instance that tracks and exposes a canceled/disposed state. -
Uses of SimpleQueue in io.reactivex.rxjava3.internal.jdk8
Fields in io.reactivex.rxjava3.internal.jdk8 declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<T>
FlowableFlatMapStream.FlatMapStreamSubscriber. queue
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.observers
Classes in io.reactivex.rxjava3.internal.observers that implement SimpleQueue Modifier and Type Class Description class
BasicFuseableObserver<T,R>
Base class for a fuseable intermediate observer.class
BasicIntQueueDisposable<T>
An abstract QueueDisposable implementation, extending an AtomicInteger, that defaults all unnecessary Queue methods to throw UnsupportedOperationException.class
BasicQueueDisposable<T>
An abstract QueueDisposable implementation that defaults all unnecessary Queue methods to throw UnsupportedOperationException.class
DeferredScalarDisposable<T>
Represents a fuseable container for a single value.class
DeferredScalarObserver<T,R>
A fuseable Observer that can generate 0 or 1 resulting value.Fields in io.reactivex.rxjava3.internal.observers declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<T>
InnerQueuedObserver. queue
Methods in io.reactivex.rxjava3.internal.observers that return SimpleQueue Modifier and Type Method Description SimpleQueue<T>
InnerQueuedObserver. queue()
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.operators.completable
Fields in io.reactivex.rxjava3.internal.operators.completable declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<CompletableSource>
CompletableConcat.CompletableConcatSubscriber. queue
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.operators.flowable
Fields in io.reactivex.rxjava3.internal.operators.flowable declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<T>
FlowableConcatMap.BaseConcatMapSubscriber. queue
(package private) SimpleQueue<T>
FlowableConcatMapScheduler.BaseConcatMapSubscriber. queue
(package private) SimpleQueue<U>
FlowableFlatMap.InnerSubscriber. queue
(package private) SimpleQueue<T>
FlowableFlattenIterable.FlattenIterableSubscriber. queue
(package private) SimpleQueue<T>
FlowableObserveOn.BaseObserveOnSubscriber. queue
(package private) SimpleQueue<T>
FlowablePublish.PublishConnection. queue
(package private) SimpleQueue<T>
FlowablePublishMulticast.MulticastProcessor. queue
(package private) SimpleQueue<T>
FlowableSequenceEqual.EqualSubscriber. queue
(package private) SimpleQueue<R>
FlowableSwitchMap.SwitchMapInnerSubscriber. queue
(package private) SimpleQueue<T>
FlowableZip.ZipSubscriber. queue
Methods in io.reactivex.rxjava3.internal.operators.flowable that return SimpleQueue Modifier and Type Method Description (package private) SimpleQueue<U>
FlowableFlatMap.MergeSubscriber. getMainQueue()
Methods in io.reactivex.rxjava3.internal.operators.flowable with parameters of type SimpleQueue Modifier and Type Method Description (package private) boolean
FlowableFlattenIterable.FlattenIterableSubscriber. checkTerminated(boolean d, boolean empty, org.reactivestreams.Subscriber<?> a, SimpleQueue<?> q)
(package private) void
FlowableGroupJoin.GroupJoinSubscription. fail(java.lang.Throwable exc, org.reactivestreams.Subscriber<?> a, SimpleQueue<?> q)
(package private) void
FlowableJoin.JoinSubscription. fail(java.lang.Throwable exc, org.reactivestreams.Subscriber<?> a, SimpleQueue<?> q)
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.operators.maybe
Subinterfaces of SimpleQueue in io.reactivex.rxjava3.internal.operators.maybe Modifier and Type Interface Description (package private) static interface
MaybeMergeArray.SimpleQueueWithConsumerIndex<T>
Classes in io.reactivex.rxjava3.internal.operators.maybe that implement SimpleQueue Modifier and Type Class Description (package private) static class
MaybeFlatMapIterableFlowable.FlatMapIterableObserver<T,R>
(package private) static class
MaybeFlatMapIterableObservable.FlatMapIterableObserver<T,R>
(package private) static class
MaybeMergeArray.ClqSimpleQueue<T>
(package private) static class
MaybeMergeArray.MergeMaybeObserver<T>
(package private) static class
MaybeMergeArray.MpscFillOnceSimpleQueue<T>
(package private) static class
MaybeToFlowable.MaybeToFlowableSubscriber<T>
(package private) static class
MaybeToObservable.MaybeToObservableObserver<T>
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.operators.mixed
Fields in io.reactivex.rxjava3.internal.operators.mixed declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<T>
ConcatMapXMainObserver. queue
(package private) SimpleQueue<T>
ConcatMapXMainSubscriber. queue
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.operators.observable
Fields in io.reactivex.rxjava3.internal.operators.observable declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<T>
ObservableConcatMap.ConcatMapDelayErrorObserver. queue
(package private) SimpleQueue<T>
ObservableConcatMap.SourceObserver. queue
(package private) SimpleQueue<T>
ObservableConcatMapEager.ConcatMapEagerMainObserver. queue
(package private) SimpleQueue<T>
ObservableConcatMapScheduler.ConcatMapDelayErrorObserver. queue
(package private) SimpleQueue<T>
ObservableConcatMapScheduler.ConcatMapObserver. queue
(package private) SimpleQueue<U>
ObservableFlatMap.InnerObserver. queue
(package private) SimpleQueue<T>
ObservableObserveOn.ObserveOnObserver. queue
(package private) SimpleQueue<R>
ObservableSwitchMap.SwitchMapInnerObserver. queue
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.operators.parallel
Classes in io.reactivex.rxjava3.internal.operators.parallel that implement SimpleQueue Modifier and Type Class Description (package private) static class
ParallelCollect.ParallelCollectSubscriber<T,C>
(package private) static class
ParallelReduce.ParallelReduceSubscriber<T,R>
(package private) static class
ParallelReduceFull.ParallelReduceFullMainSubscriber<T>
Fields in io.reactivex.rxjava3.internal.operators.parallel declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<T>
ParallelFromPublisher.ParallelDispatcher. queue
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.operators.single
Classes in io.reactivex.rxjava3.internal.operators.single that implement SimpleQueue Modifier and Type Class Description (package private) static class
SingleFlatMapIterableFlowable.FlatMapIterableObserver<T,R>
(package private) static class
SingleFlatMapIterableObservable.FlatMapIterableObserver<T,R>
(package private) static class
SingleToFlowable.SingleToFlowableObserver<T>
(package private) static class
SingleToObservable.SingleToObservableObserver<T>
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.queue
Classes in io.reactivex.rxjava3.internal.queue that implement SimpleQueue Modifier and Type Class Description class
MpscLinkedQueue<T>
A multi-producer single consumer unbounded queue. -
Uses of SimpleQueue in io.reactivex.rxjava3.internal.subscribers
Classes in io.reactivex.rxjava3.internal.subscribers that implement SimpleQueue Modifier and Type Class Description class
BasicFuseableConditionalSubscriber<T,R>
Base class for a fuseable intermediate subscriber.class
BasicFuseableSubscriber<T,R>
Base class for a fuseable intermediate subscriber.class
DeferredScalarSubscriber<T,R>
A subscriber, extending a DeferredScalarSubscription, that is unbounded-in and can generate 0 or 1 resulting value.Fields in io.reactivex.rxjava3.internal.subscribers declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<T>
InnerQueuedSubscriber. queue
Methods in io.reactivex.rxjava3.internal.subscribers that return SimpleQueue Modifier and Type Method Description SimpleQueue<T>
InnerQueuedSubscriber. queue()
-
Uses of SimpleQueue in io.reactivex.rxjava3.internal.subscriptions
Classes in io.reactivex.rxjava3.internal.subscriptions that implement SimpleQueue Modifier and Type Class Description class
BasicIntQueueSubscription<T>
Base class extending AtomicInteger (wip or request accounting) and QueueSubscription (fusion).class
BasicQueueSubscription<T>
Base class extending AtomicLong (wip or request accounting) and QueueSubscription (fusion).class
DeferredScalarSubscription<T>
A subscription that signals a single value eventually.class
EmptySubscription
An empty subscription that does nothing other than validates the request amount.class
ScalarSubscription<T>
A Subscription that holds a constant value and emits it only when requested. -
Uses of SimpleQueue in io.reactivex.rxjava3.internal.util
Methods in io.reactivex.rxjava3.internal.util that return SimpleQueue Modifier and Type Method Description static <T> SimpleQueue<T>
QueueDrainHelper. createQueue(int capacityHint)
Creates a queue: spsc-array if capacityHint is positive and spsc-linked-array if capacityHint is negative; in both cases, the capacity is the absolute value of prefetch.Methods in io.reactivex.rxjava3.internal.util with parameters of type SimpleQueue Modifier and Type Method Description static <T,U>
booleanQueueDrainHelper. checkTerminated(boolean d, boolean empty, Observer<?> observer, boolean delayError, SimpleQueue<?> q, Disposable disposable, ObservableQueueDrain<T,U> qd)
static <T,U>
booleanQueueDrainHelper. checkTerminated(boolean d, boolean empty, org.reactivestreams.Subscriber<?> s, boolean delayError, SimpleQueue<?> q, QueueDrain<T,U> qd)
-
Uses of SimpleQueue in io.reactivex.rxjava3.operators
Subinterfaces of SimpleQueue in io.reactivex.rxjava3.operators Modifier and Type Interface Description interface
QueueDisposable<T>
An interface extendingSimpleQueue
andDisposable
and allows negotiating the fusion mode between subsequent operators of theObservable
base reactive type.interface
QueueFuseable<T>
Represents aSimpleQueue
plus the means and constants for requesting a fusion mode.interface
QueueSubscription<T>
An interface extendingSimpleQueue
andSubscription
and allows negotiating the fusion mode between subsequent operators of theFlowable
base reactive type.interface
SimplePlainQueue<T>
Classes in io.reactivex.rxjava3.operators that implement SimpleQueue Modifier and Type Class Description class
SpscArrayQueue<E>
A Single-Producer-Single-Consumer queue backed by a pre-allocated buffer.class
SpscLinkedArrayQueue<T>
A single-producer single-consumer array-backed queue which can allocate new arrays in case the consumer is slower than the producer. -
Uses of SimpleQueue in io.reactivex.rxjava3.processors
Classes in io.reactivex.rxjava3.processors that implement SimpleQueue Modifier and Type Class Description (package private) static class
AsyncProcessor.AsyncSubscription<T>
(package private) class
UnicastProcessor.UnicastQueueSubscription
Fields in io.reactivex.rxjava3.processors declared as SimpleQueue Modifier and Type Field Description (package private) SimpleQueue<T>
MulticastProcessor. queue
-
Uses of SimpleQueue in io.reactivex.rxjava3.subjects
Classes in io.reactivex.rxjava3.subjects that implement SimpleQueue Modifier and Type Class Description (package private) static class
AsyncSubject.AsyncDisposable<T>
(package private) class
UnicastSubject.UnicastQueueDisposable
Methods in io.reactivex.rxjava3.subjects with parameters of type SimpleQueue Modifier and Type Method Description (package private) boolean
UnicastSubject. failedFast(SimpleQueue<T> q, Observer<? super T> a)
-