All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractBackpressureThrottlingSubscriber<T,R> |
Abstract base class for operators that throttle excessive updates from upstream in case if
downstream Subscriber is not ready to receive updates.
|
AbstractDirectTask |
Base functionality for direct tasks that manage a runnable and cancellation/completion.
|
AbstractDisposableAutoRelease |
Wraps lambda callbacks and when the upstream terminates or the observer gets disposed,
removes itself from a CompositeDisposable .
|
AbstractEmptyQueueFuseable<T> |
|
AbstractFlowableWithUpstream<T,R> |
Abstract base class for operators that take an upstream
source Publisher .
|
AbstractMaybeWithUpstream<T,R> |
Abstract base class for intermediate Maybe operators that take an upstream MaybeSource.
|
AbstractObservableWithUpstream<T,U> |
Base class for operators with a source consumable.
|
Action |
A functional interface similar to Runnable but allows throwing a checked exception.
|
ActionDisposable |
A Disposable container that manages an Action instance.
|
AppendOnlyLinkedArrayList<T> |
A linked-array-list implementation that only supports appending and consumption.
|
AppendOnlyLinkedArrayList.NonThrowingPredicate<T> |
Predicate interface suppressing the exception.
|
ArrayCompositeDisposable |
A composite disposable with a fixed number of slots.
|
ArrayCompositeSubscription |
A composite disposable with a fixed number of slots.
|
ArrayListSupplier |
|
AsyncProcessor<T> |
Processor that emits the very last value followed by a completion event or the received error
to Subscriber s.
|
AsyncProcessor.AsyncSubscription<T> |
|
AsyncSubject<T> |
A Subject that emits the very last value followed by a completion event or the received error to Observers.
|
AsyncSubject.AsyncDisposable<T> |
|
AsyncSubscription |
A subscription implementation that arbitrates exactly one other Subscription and can
hold a single disposable resource.
|
AtomicThrowable |
Atomic container for Throwables including combining and having a
terminal state via ExceptionHelper.
|
AutoCloseableDisposable |
A disposable container that manages an AutoCloseable instance.
|
BackpressureHelper |
Utility class to help with backpressure-related operations such as request aggregation.
|
BackpressureKind |
Enumeration for various kinds of backpressure support.
|
BackpressureOverflowStrategy |
Options to deal with buffer overflow when using onBackpressureBuffer.
|
BackpressureStrategy |
Represents the options for applying backpressure to a source sequence.
|
BackpressureSupport |
Indicates the backpressure support kind of the associated operator or class.
|
BaseTestConsumer<T,U extends BaseTestConsumer<T,U>> |
|
BasicFuseableConditionalSubscriber<T,R> |
Base class for a fuseable intermediate subscriber.
|
BasicFuseableObserver<T,R> |
Base class for a fuseable intermediate observer.
|
BasicFuseableSubscriber<T,R> |
Base class for a fuseable intermediate subscriber.
|
BasicIntQueueDisposable<T> |
An abstract QueueDisposable implementation, extending an AtomicInteger,
that defaults all unnecessary Queue methods to throw UnsupportedOperationException.
|
BasicIntQueueSubscription<T> |
Base class extending AtomicInteger (wip or request accounting) and QueueSubscription (fusion).
|
BasicQueueDisposable<T> |
An abstract QueueDisposable implementation that defaults all
unnecessary Queue methods to throw UnsupportedOperationException.
|
BasicQueueSubscription<T> |
Base class extending AtomicLong (wip or request accounting) and QueueSubscription (fusion).
|
BehaviorProcessor<T> |
Processor that emits the most recent item it has observed and all subsequent observed items to each subscribed
Subscriber .
|
BehaviorProcessor.BehaviorSubscription<T> |
|
BehaviorSubject<T> |
Subject that emits the most recent item it has observed and all subsequent observed items to each subscribed
Observer .
|
BehaviorSubject.BehaviorDisposable<T> |
|
Beta |
Indicates the feature is in beta state: it will be most likely stay but
the signature may change between versions without warning.
|
BiConsumer<T1,T2> |
A functional interface (callback) that accepts two values (of possibly different types).
|
BiConsumerSingleObserver<T> |
|
BiFunction<T1,T2,R> |
A functional interface (callback) that computes a value based on multiple input values.
|
BiPredicate<T1,T2> |
A functional interface (callback) that returns true or false for the given input values.
|
BlockingBaseObserver<T> |
|
BlockingBaseSubscriber<T> |
|
BlockingDisposableMultiObserver<T> |
Blocks until the upstream terminates and dispatches the outcome to
the actual observer.
|
BlockingFirstObserver<T> |
Blocks until the upstream signals its first value or completes.
|
BlockingFirstSubscriber<T> |
Blocks until the upstream signals its first value or completes.
|
BlockingFlowableIterable<T> |
|
BlockingFlowableIterable.BlockingFlowableIterator<T> |
|
BlockingFlowableLatest<T> |
Wait for and iterate over the latest values of the source observable.
|
BlockingFlowableLatest.LatestSubscriberIterator<T> |
Subscriber of source, iterator for output.
|
BlockingFlowableMostRecent<T> |
Returns an Iterable that always returns the item most recently emitted by an Observable, or a
seed value if no item has yet been emitted.
|
BlockingFlowableMostRecent.MostRecentSubscriber<T> |
|
BlockingFlowableNext<T> |
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
|
BlockingFlowableNext.NextIterator<T> |
|
BlockingFlowableNext.NextSubscriber<T> |
|
BlockingHelper |
Utility methods for helping common blocking operations.
|
BlockingIgnoringReceiver |
Stores an incoming Throwable (if any) and counts itself down.
|
BlockingLastObserver<T> |
Blocks until the upstream signals its last value or completes.
|
BlockingLastSubscriber<T> |
Blocks until the upstream signals its last value or completes.
|
BlockingMultiObserver<T> |
A combined Observer that awaits the success or error signal via a CountDownLatch.
|
BlockingObservableIterable<T> |
|
BlockingObservableIterable.BlockingObservableIterator<T> |
|
BlockingObservableLatest<T> |
Wait for and iterate over the latest values of the source observable.
|
BlockingObservableLatest.BlockingObservableLatestIterator<T> |
|
BlockingObservableMostRecent<T> |
Returns an Iterable that always returns the item most recently emitted by an Observable, or a
seed value if no item has yet been emitted.
|
BlockingObservableMostRecent.MostRecentObserver<T> |
|
BlockingObservableNext<T> |
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
|
BlockingObservableNext.NextIterator<T> |
|
BlockingObservableNext.NextObserver<T> |
|
BlockingObserver<T> |
|
BlockingSubscriber<T> |
|
BooleanSubscription |
Subscription implementation that ignores request but remembers the cancellation
which can be checked via isCancelled.
|
BooleanSupplier |
A functional interface (callback) that returns a boolean value.
|
BoundedSubscriber<T> |
|
CallbackCompletableObserver |
|
Cancellable |
A functional interface that has a single cancel method
that can throw.
|
CancellableDisposable |
A disposable container that wraps a Cancellable instance.
|
CancellableQueueFuseable<T> |
Represents an empty, async-only QueueFuseable instance that tracks and exposes a
canceled/disposed state.
|
CheckReturnValue |
Marks methods whose return values should be checked.
|
Completable |
The Completable class represents a deferred computation without any value but
only indication for completion or exception.
|
CompletableAmb |
|
CompletableAmb.Amb |
|
CompletableAndThenCompletable |
|
CompletableAndThenCompletable.NextObserver |
|
CompletableAndThenCompletable.SourceObserver |
|
CompletableAndThenObservable<R> |
After Completable completes, it relays the signals
of the ObservableSource to the downstream observer.
|
CompletableAndThenObservable.AndThenObservableObserver<R> |
|
CompletableAndThenPublisher<R> |
After Completable completes, it relays the signals
of the Publisher to the downstream subscriber.
|
CompletableAndThenPublisher.AndThenPublisherSubscriber<R> |
|
CompletableCache |
Consume the upstream source exactly once and cache its terminal event.
|
CompletableConcat |
|
CompletableConcat.CompletableConcatSubscriber |
|
CompletableConcat.CompletableConcatSubscriber.ConcatInnerObserver |
|
CompletableConcatArray |
|
CompletableConcatArray.ConcatInnerObserver |
|
CompletableConcatIterable |
|
CompletableConcatIterable.ConcatInnerObserver |
|
CompletableConverter<R> |
|
CompletableCreate |
|
CompletableCreate.Emitter |
|
CompletableDefer |
|
CompletableDelay |
|
CompletableDelay.Delay |
|
CompletableDetach |
Breaks the references between the upstream and downstream when the Completable terminates.
|
CompletableDetach.DetachCompletableObserver |
|
CompletableDisposeOn |
|
CompletableDisposeOn.DisposeOnObserver |
|
CompletableDoFinally |
Execute an action after an onError, onComplete or a dispose event.
|
CompletableDoFinally.DoFinallyObserver |
|
CompletableDoOnEvent |
|
CompletableEmitter |
|
CompletableEmpty |
|
CompletableError |
|
CompletableErrorSupplier |
|
CompletableFromAction |
|
CompletableFromCallable |
|
CompletableFromCompletionStage<T> |
Wrap a CompletionStage and signal its outcome.
|
CompletableFromCompletionStage.CompletionStageHandler<T> |
|
CompletableFromObservable<T> |
|
CompletableFromObservable.CompletableFromObservableObserver<T> |
|
CompletableFromPublisher<T> |
|
CompletableFromPublisher.FromPublisherSubscriber<T> |
|
CompletableFromRunnable |
|
CompletableFromSingle<T> |
|
CompletableFromSingle.CompletableFromSingleObserver<T> |
|
CompletableFromSupplier |
Call a Supplier for each incoming CompletableObserver and signal completion or the thrown exception.
|
CompletableFromUnsafeSource |
|
CompletableHide |
Hides the identity of the upstream Completable and its Disposable sent through onSubscribe.
|
CompletableHide.HideCompletableObserver |
|
CompletableLift |
|
CompletableMaterialize<T> |
Turn the signal types of a Completable source into a single Notification of
equal kind.
|
CompletableMerge |
|
CompletableMerge.CompletableMergeSubscriber |
|
CompletableMergeArray |
|
CompletableMergeArray.InnerCompletableObserver |
|
CompletableMergeArrayDelayError |
|
CompletableMergeArrayDelayError.MergeInnerCompletableObserver |
|
CompletableMergeArrayDelayError.TryTerminateAndReportDisposable |
|
CompletableMergeDelayErrorIterable |
|
CompletableMergeIterable |
|
CompletableMergeIterable.MergeCompletableObserver |
|
CompletableNever |
|
CompletableObserveOn |
|
CompletableObserveOn.ObserveOnCompletableObserver |
|
CompletableObserver |
Provides a mechanism for receiving push-based notification of a valueless completion or an error.
|
CompletableOnErrorComplete |
|
CompletableOnErrorComplete.OnError |
|
CompletableOnErrorReturn<T> |
Returns a value generated via a function if the main source signals an onError.
|
CompletableOnErrorReturn.OnErrorReturnMaybeObserver<T> |
|
CompletableOnSubscribe |
A functional interface that has a subscribe() method that receives
a CompletableEmitter instance that allows pushing
an event in a cancellation-safe manner.
|
CompletableOperator |
Interface to map/wrap a downstream observer to an upstream observer.
|
CompletablePeek |
|
CompletableResumeNext |
|
CompletableResumeNext.ResumeNextObserver |
|
CompletableSource |
|
CompletableSubject |
Represents a hot Completable-like source and consumer of events similar to Subjects.
|
CompletableSubject.CompletableDisposable |
|
CompletableSubscribeOn |
|
CompletableSubscribeOn.SubscribeOnObserver |
|
CompletableTakeUntilCompletable |
Terminates the sequence if either the main or the other Completable terminate.
|
CompletableTakeUntilCompletable.TakeUntilMainObserver |
|
CompletableTakeUntilCompletable.TakeUntilMainObserver.OtherObserver |
|
CompletableTimeout |
|
CompletableTimeout.TimeOutObserver |
|
CompletableTimer |
Signals an onComplete event after the specified delay.
|
CompletableTimer.TimerDisposable |
|
CompletableToFlowable<T> |
|
CompletableToObservable<T> |
Wraps a Completable and exposes it as an Observable.
|
CompletableToSingle<T> |
|
CompletableTransformer |
Convenience interface and callback used by the compose operator to turn a Completable into another
Completable fluently.
|
CompletableUsing<R> |
|
CompletableUsing.UsingObserver<R> |
|
CompletionStageConsumer<T> |
Class that extends CompletableFuture and converts multiple types of reactive consumers
and their signals into completion signals.
|
CompositeDisposable |
|
CompositeException |
Represents an exception that is a composite of one or more other exceptions.
|
CompositeException.ExceptionOverview |
Contains a formatted message with a simplified representation of the exception graph
contained within the CompositeException.
|
CompositeException.PrintStreamOrWriter |
|
CompositeException.WrappedPrintStream |
Same abstraction and implementation as in JDK to allow PrintStream and PrintWriter to share implementation.
|
CompositeException.WrappedPrintWriter |
Same abstraction and implementation as in JDK to allow PrintStream and PrintWriter to share implementation.
|
ComputationScheduler |
Holds a fixed pool of worker threads and assigns them
to requested Scheduler.Workers in a round-robin fashion.
|
ComputationScheduler.EventLoopWorker |
|
ComputationScheduler.FixedSchedulerPool |
|
ComputationScheduler.PoolWorker |
|
ConcatMapXMainObserver<T> |
Base class for implementing concatMapX main observers.
|
ConcatMapXMainSubscriber<T> |
Base class for implementing concatMapX main subscribers.
|
ConditionalSubscriber<T> |
|
ConnectableFlowable<T> |
|
ConnectableObservable<T> |
|
ConnectConsumer |
Store the Disposable received from the connection.
|
Consumer<T> |
A functional interface (callback) that accepts a single value.
|
ConsumerSingleObserver<T> |
|
DefaultObserver<T> |
|
DefaultSubscriber<T> |
|
DeferredScalarDisposable<T> |
Represents a fuseable container for a single value.
|
DeferredScalarObserver<T,R> |
A fuseable Observer that can generate 0 or 1 resulting value.
|
DeferredScalarSubscriber<T,R> |
A subscriber, extending a DeferredScalarSubscription,
that is unbounded-in and can generate 0 or 1 resulting value.
|
DeferredScalarSubscription<T> |
A subscription that signals a single value eventually.
|
Disposable |
Represents a disposable resource.
|
DisposableAutoReleaseMultiObserver<T> |
Wraps lambda callbacks and when the upstream terminates or this (Single | Maybe | Completable)
observer gets disposed, removes itself from a CompositeDisposable .
|
DisposableAutoReleaseObserver<T> |
Wraps lambda callbacks and when the upstream terminates or this observer gets disposed,
removes itself from a CompositeDisposable .
|
DisposableAutoReleaseSubscriber<T> |
Wraps lambda callbacks and when the upstream terminates or this subscriber gets disposed,
removes itself from a CompositeDisposable .
|
DisposableCompletableObserver |
An abstract CompletableObserver that allows asynchronous cancellation by implementing Disposable.
|
DisposableContainer |
Common interface to add and remove disposables from a container.
|
DisposableHelper |
Utility methods for working with Disposables atomically.
|
DisposableLambdaObserver<T> |
|
DisposableMaybeObserver<T> |
|
DisposableObserver<T> |
|
DisposableSingleObserver<T> |
|
DisposableSubscriber<T> |
An abstract Subscriber that allows asynchronous, external cancellation by implementing Disposable .
|
DisposeOnCancel |
Implements the Future interface and calls dispose() on cancel() but
the other methods are not implemented.
|
Emitter<T> |
Base interface for emitting signals in a push-fashion in various generator-like source
operators (create, generate).
|
EmptyCompletableObserver |
|
EmptyComponent |
Singleton implementing many interfaces as empty.
|
EmptyDisposable |
Represents a stateless empty Disposable that reports being always
empty and disposed.
|
EmptySubscription |
An empty subscription that does nothing other than validates the request amount.
|
EndConsumerHelper |
Utility class to help report multiple subscriptions with the same
consumer type instead of the internal "Disposable already set!" message
that is practically reserved for internal operators and indicate bugs in them.
|
ErrorMode |
Indicates when an error from the main source should be reported.
|
ExceptionHelper |
Terminal atomics for Throwable containers.
|
ExceptionHelper.Termination |
|
Exceptions |
Utility class to help propagate checked exceptions and rethrow exceptions
designated as fatal.
|
ExecutorScheduler |
Wraps an Executor and provides the Scheduler API over it.
|
ExecutorScheduler.DelayedRunnable |
|
ExecutorScheduler.ExecutorWorker |
|
ExecutorScheduler.ExecutorWorker.BooleanRunnable |
|
ExecutorScheduler.ExecutorWorker.InterruptibleRunnable |
Wrapper for a Runnable with additional logic for handling interruption on
a shared thread, similar to how Java Executors do it.
|
ExecutorScheduler.SingleHolder |
|
Experimental |
Indicates the feature is in experimental state: its existence, signature or behavior
might change without warning from one release to the next.
|
Flowable<T> |
The Flowable class that implements the Reactive Streams Publisher
Pattern and offers factory methods, intermediate operators and the ability to consume reactive dataflows.
|
FlowableAll<T> |
|
FlowableAll.AllSubscriber<T> |
|
FlowableAllSingle<T> |
|
FlowableAllSingle.AllSubscriber<T> |
|
FlowableAmb<T> |
|
FlowableAmb.AmbCoordinator<T> |
|
FlowableAmb.AmbInnerSubscriber<T> |
|
FlowableAny<T> |
|
FlowableAny.AnySubscriber<T> |
|
FlowableAnySingle<T> |
|
FlowableAnySingle.AnySubscriber<T> |
|
FlowableAutoConnect<T> |
Wraps a ConnectableFlowable and calls its connect() method once
the specified number of Subscriber s have subscribed.
|
FlowableBlockingSubscribe |
Utility methods to consume a Publisher in a blocking manner with callbacks or Subscriber.
|
FlowableBuffer<T,C extends java.util.Collection<? super T>> |
|
FlowableBuffer.PublisherBufferExactSubscriber<T,C extends java.util.Collection<? super T>> |
|
FlowableBuffer.PublisherBufferOverlappingSubscriber<T,C extends java.util.Collection<? super T>> |
|
FlowableBuffer.PublisherBufferSkipSubscriber<T,C extends java.util.Collection<? super T>> |
|
FlowableBufferBoundary<T,U extends java.util.Collection<? super T>,Open,Close> |
|
FlowableBufferBoundary.BufferBoundarySubscriber<T,C extends java.util.Collection<? super T>,Open,Close> |
|
FlowableBufferBoundary.BufferBoundarySubscriber.BufferOpenSubscriber<Open> |
|
FlowableBufferBoundary.BufferCloseSubscriber<T,C extends java.util.Collection<? super T>> |
|
FlowableBufferExactBoundary<T,U extends java.util.Collection<? super T>,B> |
|
FlowableBufferExactBoundary.BufferBoundarySubscriber<T,U extends java.util.Collection<? super T>,B> |
|
FlowableBufferExactBoundary.BufferExactBoundarySubscriber<T,U extends java.util.Collection<? super T>,B> |
|
FlowableBufferTimed<T,U extends java.util.Collection<? super T>> |
|
FlowableBufferTimed.BufferExactBoundedSubscriber<T,U extends java.util.Collection<? super T>> |
|
FlowableBufferTimed.BufferExactUnboundedSubscriber<T,U extends java.util.Collection<? super T>> |
|
FlowableBufferTimed.BufferSkipBoundedSubscriber<T,U extends java.util.Collection<? super T>> |
|
FlowableCache<T> |
An observable which auto-connects to another observable, caches the elements
from that observable but allows terminating the connection and completing the cache.
|
FlowableCache.CacheSubscription<T> |
Hosts the downstream consumer and its current requested and replay states.
|
FlowableCache.Node<T> |
Represents a segment of the cached item list as
part of a linked-node-list structure.
|
FlowableCollect<T,U> |
|
FlowableCollect.CollectSubscriber<T,U> |
|
FlowableCollectSingle<T,U> |
|
FlowableCollectSingle.CollectSubscriber<T,U> |
|
FlowableCollectWithCollector<T,A,R> |
Collect items into a container defined by a Stream Collector callback set.
|
FlowableCollectWithCollector.CollectorSubscriber<T,A,R> |
|
FlowableCollectWithCollectorSingle<T,A,R> |
Collect items into a container defined by a Stream Collector callback set.
|
FlowableCollectWithCollectorSingle.CollectorSingleObserver<T,A,R> |
|
FlowableCombineLatest<T,R> |
Combines the latest values from multiple sources through a function.
|
FlowableCombineLatest.CombineLatestCoordinator<T,R> |
|
FlowableCombineLatest.CombineLatestInnerSubscriber<T> |
|
FlowableConcatArray<T> |
|
FlowableConcatArray.ConcatArraySubscriber<T> |
|
FlowableConcatMap<T,R> |
|
FlowableConcatMap.BaseConcatMapSubscriber<T,R> |
|
FlowableConcatMap.ConcatMapDelayed<T,R> |
|
FlowableConcatMap.ConcatMapImmediate<T,R> |
|
FlowableConcatMap.ConcatMapInner<R> |
|
FlowableConcatMap.ConcatMapSupport<T> |
|
FlowableConcatMap.SimpleScalarSubscription<T> |
|
FlowableConcatMapCompletable<T> |
Maps the upstream items into CompletableSource s and subscribes to them one after the
other completes or terminates (in error-delaying mode).
|
FlowableConcatMapCompletable.ConcatMapCompletableObserver<T> |
|
FlowableConcatMapCompletable.ConcatMapCompletableObserver.ConcatMapInnerObserver |
|
FlowableConcatMapEager<T,R> |
|
FlowableConcatMapEager.ConcatMapEagerDelayErrorSubscriber<T,R> |
|
FlowableConcatMapEagerPublisher<T,R> |
ConcatMapEager which works with an arbitrary Publisher source.
|
FlowableConcatMapMaybe<T,R> |
Maps each upstream item into a MaybeSource , subscribes to them one after the other terminates
and relays their success values, optionally delaying any errors till the main and inner sources
terminate.
|
FlowableConcatMapMaybe.ConcatMapMaybeSubscriber<T,R> |
|
FlowableConcatMapMaybe.ConcatMapMaybeSubscriber.ConcatMapMaybeObserver<R> |
|
FlowableConcatMapMaybePublisher<T,R> |
Maps each upstream item into a MaybeSource , subscribes to them one after the other terminates
and relays their success values, optionally delaying any errors till the main and inner sources
terminate.
|
FlowableConcatMapScheduler<T,R> |
|
FlowableConcatMapScheduler.BaseConcatMapSubscriber<T,R> |
|
FlowableConcatMapScheduler.ConcatMapDelayed<T,R> |
|
FlowableConcatMapScheduler.ConcatMapImmediate<T,R> |
|
FlowableConcatMapSingle<T,R> |
Maps each upstream item into a SingleSource , subscribes to them one after the other terminates
and relays their success values, optionally delaying any errors till the main and inner sources
terminate.
|
FlowableConcatMapSingle.ConcatMapSingleSubscriber<T,R> |
|
FlowableConcatMapSingle.ConcatMapSingleSubscriber.ConcatMapSingleObserver<R> |
|
FlowableConcatMapSinglePublisher<T,R> |
Maps each upstream item into a SingleSource , subscribes to them one after the other terminates
and relays their success values, optionally delaying any errors till the main and inner sources
terminate.
|
FlowableConcatWithCompletable<T> |
Subscribe to a main Flowable first, then when it completes normally, subscribe to a Completable
and terminate when it terminates.
|
FlowableConcatWithCompletable.ConcatWithSubscriber<T> |
|
FlowableConcatWithMaybe<T> |
Subscribe to a main Flowable first, then when it completes normally, subscribe to a Maybe,
signal its success value followed by a completion or signal its error or completion signal as is.
|
FlowableConcatWithMaybe.ConcatWithSubscriber<T> |
|
FlowableConcatWithSingle<T> |
Subscribe to a main Flowable first, then when it completes normally, subscribe to a Single,
signal its success value followed by a completion or signal its error as is.
|
FlowableConcatWithSingle.ConcatWithSubscriber<T> |
|
FlowableConverter<T,R> |
|
FlowableCount<T> |
|
FlowableCount.CountSubscriber |
|
FlowableCountSingle<T> |
|
FlowableCountSingle.CountSubscriber |
|
FlowableCreate<T> |
|
FlowableCreate.BaseEmitter<T> |
|
FlowableCreate.BufferAsyncEmitter<T> |
|
FlowableCreate.DropAsyncEmitter<T> |
|
FlowableCreate.ErrorAsyncEmitter<T> |
|
FlowableCreate.LatestAsyncEmitter<T> |
|
FlowableCreate.MissingEmitter<T> |
|
FlowableCreate.NoOverflowBaseAsyncEmitter<T> |
|
FlowableCreate.SerializedEmitter<T> |
Serializes calls to onNext, onError and onComplete.
|
FlowableDebounce<T,U> |
|
FlowableDebounce.DebounceSubscriber<T,U> |
|
FlowableDebounce.DebounceSubscriber.DebounceInnerSubscriber<T,U> |
|
FlowableDebounceTimed<T> |
|
FlowableDebounceTimed.DebounceEmitter<T> |
|
FlowableDebounceTimed.DebounceTimedSubscriber<T> |
|
FlowableDefer<T> |
|
FlowableDelay<T> |
|
FlowableDelay.DelaySubscriber<T> |
|
FlowableDelaySubscriptionOther<T,U> |
Delays the subscription to the main source until the other
observable fires an event or completes.
|
FlowableDelaySubscriptionOther.MainSubscriber<T> |
|
FlowableDematerialize<T,R> |
|
FlowableDematerialize.DematerializeSubscriber<T,R> |
|
FlowableDetach<T> |
|
FlowableDetach.DetachSubscriber<T> |
|
FlowableDistinct<T,K> |
|
FlowableDistinct.DistinctSubscriber<T,K> |
|
FlowableDistinctUntilChanged<T,K> |
|
FlowableDistinctUntilChanged.DistinctUntilChangedConditionalSubscriber<T,K> |
|
FlowableDistinctUntilChanged.DistinctUntilChangedSubscriber<T,K> |
|
FlowableDoAfterNext<T> |
Calls a consumer after pushing the current item to the downstream.
|
FlowableDoAfterNext.DoAfterConditionalSubscriber<T> |
|
FlowableDoAfterNext.DoAfterSubscriber<T> |
|
FlowableDoFinally<T> |
Execute an action after an onError, onComplete or a cancel event.
|
FlowableDoFinally.DoFinallyConditionalSubscriber<T> |
|
FlowableDoFinally.DoFinallySubscriber<T> |
|
FlowableDoOnEach<T> |
|
FlowableDoOnEach.DoOnEachConditionalSubscriber<T> |
|
FlowableDoOnEach.DoOnEachSubscriber<T> |
|
FlowableDoOnLifecycle<T> |
|
FlowableDoOnLifecycle.SubscriptionLambdaSubscriber<T> |
|
FlowableElementAt<T> |
|
FlowableElementAt.ElementAtSubscriber<T> |
|
FlowableElementAtMaybe<T> |
|
FlowableElementAtMaybe.ElementAtSubscriber<T> |
|
FlowableElementAtMaybePublisher<T> |
Emits the indexth element from a Publisher as a Maybe.
|
FlowableElementAtSingle<T> |
|
FlowableElementAtSingle.ElementAtSubscriber<T> |
|
FlowableEmitter<T> |
Abstraction over a Reactive Streams Subscriber that allows associating
a resource with it and exposes the current number of downstream
requested amount.
|
FlowableEmpty |
A source Flowable that signals an onSubscribe() + onComplete() only.
|
FlowableError<T> |
|
FlowableFilter<T> |
|
FlowableFilter.FilterConditionalSubscriber<T> |
|
FlowableFilter.FilterSubscriber<T> |
|
FlowableFirstStageSubscriber<T> |
Signals the first element of the source via the underlying CompletableFuture,
signals the a default item if the upstream is empty or signals NoSuchElementException .
|
FlowableFlatMap<T,U> |
|
FlowableFlatMap.InnerSubscriber<T,U> |
|
FlowableFlatMap.MergeSubscriber<T,U> |
|
FlowableFlatMapCompletable<T> |
Maps a sequence of values into CompletableSources and awaits their termination.
|
FlowableFlatMapCompletable.FlatMapCompletableMainSubscriber<T> |
|
FlowableFlatMapCompletableCompletable<T> |
Maps a sequence of values into CompletableSources and awaits their termination.
|
FlowableFlatMapCompletableCompletable.FlatMapCompletableMainSubscriber<T> |
|
FlowableFlatMapMaybe<T,R> |
Maps upstream values into MaybeSources and merges their signals into one sequence.
|
FlowableFlatMapMaybe.FlatMapMaybeSubscriber<T,R> |
|
FlowableFlatMapMaybePublisher<T,R> |
Maps upstream values into MaybeSources and merges their signals into one sequence.
|
FlowableFlatMapSingle<T,R> |
Maps upstream values into SingleSources and merges their signals into one sequence.
|
FlowableFlatMapSingle.FlatMapSingleSubscriber<T,R> |
|
FlowableFlatMapSinglePublisher<T,R> |
Maps upstream values into SingleSources and merges their signals into one sequence.
|
FlowableFlatMapStream<T,R> |
Maps the upstream values onto Stream s and emits their items in order to the downstream.
|
FlowableFlatMapStream.FlatMapStreamSubscriber<T,R> |
|
FlowableFlattenIterable<T,R> |
|
FlowableFlattenIterable.FlattenIterableSubscriber<T,R> |
|
FlowableFromAction<T> |
Executes an Action and signals its exception or completes normally.
|
FlowableFromArray<T> |
|
FlowableFromArray.ArrayConditionalSubscription<T> |
|
FlowableFromArray.ArraySubscription<T> |
|
FlowableFromArray.BaseArraySubscription<T> |
|
FlowableFromCallable<T> |
|
FlowableFromCompletable<T> |
Wrap a Completable into a Flowable.
|
FlowableFromCompletable.FromCompletableObserver<T> |
|
FlowableFromCompletionStage<T> |
Wrap a CompletionStage and signal its outcome.
|
FlowableFromCompletionStage.BiConsumerAtomicReference<T> |
|
FlowableFromCompletionStage.CompletionStageHandler<T> |
|
FlowableFromFuture<T> |
|
FlowableFromIterable<T> |
|
FlowableFromIterable.BaseRangeSubscription<T> |
|
FlowableFromIterable.IteratorConditionalSubscription<T> |
|
FlowableFromIterable.IteratorSubscription<T> |
|
FlowableFromObservable<T> |
|
FlowableFromObservable.SubscriberObserver<T> |
|
FlowableFromPublisher<T> |
|
FlowableFromRunnable<T> |
Executes an Runnable and signals its exception or completes normally.
|
FlowableFromStream<T> |
Wraps a Stream and emits its values as a Flowable sequence.
|
FlowableFromStream.AbstractStreamSubscription<T> |
|
FlowableFromStream.StreamConditionalSubscription<T> |
|
FlowableFromStream.StreamSubscription<T> |
|
FlowableFromSupplier<T> |
Call a Supplier for each incoming Subscriber and signal the returned value or the thrown exception.
|
FlowableGenerate<T,S> |
|
FlowableGenerate.GeneratorSubscription<T,S> |
|
FlowableGroupBy<T,K,V> |
|
FlowableGroupBy.EvictionAction<K,V> |
|
FlowableGroupBy.GroupBySubscriber<T,K,V> |
|
FlowableGroupBy.GroupedUnicast<K,T> |
|
FlowableGroupBy.State<T,K> |
|
FlowableGroupJoin<TLeft,TRight,TLeftEnd,TRightEnd,R> |
|
FlowableGroupJoin.GroupJoinSubscription<TLeft,TRight,TLeftEnd,TRightEnd,R> |
|
FlowableGroupJoin.JoinSupport |
|
FlowableGroupJoin.LeftRightEndSubscriber |
|
FlowableGroupJoin.LeftRightSubscriber |
|
FlowableHide<T> |
Hides the identity of the wrapped Flowable and its Subscription.
|
FlowableHide.HideSubscriber<T> |
|
FlowableIgnoreElements<T> |
|
FlowableIgnoreElements.IgnoreElementsSubscriber<T> |
|
FlowableIgnoreElementsCompletable<T> |
|
FlowableIgnoreElementsCompletable.IgnoreElementsSubscriber<T> |
|
FlowableInternalHelper |
Helper utility class to support Flowable with inner classes.
|
FlowableInternalHelper.BufferedReplaySupplier<T> |
|
FlowableInternalHelper.BufferedTimedReplay<T> |
|
FlowableInternalHelper.FlatMapIntoIterable<T,U> |
|
FlowableInternalHelper.FlatMapWithCombinerInner<U,R,T> |
|
FlowableInternalHelper.FlatMapWithCombinerOuter<T,R,U> |
|
FlowableInternalHelper.ItemDelayFunction<T,U> |
|
FlowableInternalHelper.ReplaySupplier<T> |
|
FlowableInternalHelper.RequestMax |
|
FlowableInternalHelper.SimpleBiGenerator<T,S> |
|
FlowableInternalHelper.SimpleGenerator<T,S> |
|
FlowableInternalHelper.SubscriberOnComplete<T> |
|
FlowableInternalHelper.SubscriberOnError<T> |
|
FlowableInternalHelper.SubscriberOnNext<T> |
|
FlowableInternalHelper.TimedReplay<T> |
|
FlowableInterval |
|
FlowableInterval.IntervalSubscriber |
|
FlowableIntervalRange |
|
FlowableIntervalRange.IntervalRangeSubscriber |
|
FlowableJoin<TLeft,TRight,TLeftEnd,TRightEnd,R> |
|
FlowableJoin.JoinSubscription<TLeft,TRight,TLeftEnd,TRightEnd,R> |
|
FlowableJust<T> |
Represents a constant scalar value.
|
FlowableLastMaybe<T> |
Consumes the source Publisher and emits its last item or completes.
|
FlowableLastMaybe.LastSubscriber<T> |
|
FlowableLastSingle<T> |
Consumes the source Publisher and emits its last item or the defaultItem
if empty.
|
FlowableLastSingle.LastSubscriber<T> |
|
FlowableLastStageSubscriber<T> |
Signals the last element of the source via the underlying CompletableFuture,
signals the a default item if the upstream is empty or signals NoSuchElementException .
|
FlowableLift<R,T> |
Allows lifting operators into a chain of Publishers.
|
FlowableMap<T,U> |
|
FlowableMap.MapConditionalSubscriber<T,U> |
|
FlowableMap.MapSubscriber<T,U> |
|
FlowableMapNotification<T,R> |
|
FlowableMapNotification.MapNotificationSubscriber<T,R> |
|
FlowableMapOptional<T,R> |
Map the upstream values into an Optional and emit its value if any.
|
FlowableMapOptional.MapOptionalConditionalSubscriber<T,R> |
|
FlowableMapOptional.MapOptionalSubscriber<T,R> |
|
FlowableMapPublisher<T,U> |
Map working with an arbitrary Publisher source.
|
FlowableMaterialize<T> |
|
FlowableMaterialize.MaterializeSubscriber<T> |
|
FlowableMergeWithCompletable<T> |
Merges a Flowable and a Completable by emitting the items of the Flowable and waiting until
both the Flowable and Completable complete normally.
|
FlowableMergeWithCompletable.MergeWithSubscriber<T> |
|
FlowableMergeWithCompletable.MergeWithSubscriber.OtherObserver |
|
FlowableMergeWithMaybe<T> |
Merges an Observable and a Maybe by emitting the items of the Observable and the success
value of the Maybe and waiting until both the Observable and Maybe terminate normally.
|
FlowableMergeWithMaybe.MergeWithObserver<T> |
|
FlowableMergeWithMaybe.MergeWithObserver.OtherObserver<T> |
|
FlowableMergeWithSingle<T> |
Merges an Observable and a Maybe by emitting the items of the Observable and the success
value of the Maybe and waiting until both the Observable and Maybe terminate normally.
|
FlowableMergeWithSingle.MergeWithObserver<T> |
|
FlowableMergeWithSingle.MergeWithObserver.OtherObserver<T> |
|
FlowableNever |
|
FlowableObserveOn<T> |
|
FlowableObserveOn.BaseObserveOnSubscriber<T> |
|
FlowableObserveOn.ObserveOnConditionalSubscriber<T> |
|
FlowableObserveOn.ObserveOnSubscriber<T> |
|
FlowableOnBackpressureBuffer<T> |
|
FlowableOnBackpressureBuffer.BackpressureBufferSubscriber<T> |
|
FlowableOnBackpressureBufferStrategy<T> |
Handle backpressure with a bounded buffer and custom strategy.
|
FlowableOnBackpressureBufferStrategy.OnBackpressureBufferStrategySubscriber<T> |
|
FlowableOnBackpressureDrop<T> |
|
FlowableOnBackpressureDrop.BackpressureDropSubscriber<T> |
|
FlowableOnBackpressureError<T> |
|
FlowableOnBackpressureError.BackpressureErrorSubscriber<T> |
|
FlowableOnBackpressureLatest<T> |
|
FlowableOnBackpressureLatest.BackpressureLatestSubscriber<T> |
|
FlowableOnBackpressureReduce<T> |
|
FlowableOnBackpressureReduce.BackpressureReduceSubscriber<T> |
|
FlowableOnBackpressureReduceWith<T,R> |
|
FlowableOnBackpressureReduceWith.BackpressureReduceWithSubscriber<T,R> |
|
FlowableOnErrorComplete<T> |
Emits an onComplete if the source emits an onError and the predicate returns true for
that Throwable.
|
FlowableOnErrorComplete.OnErrorCompleteSubscriber<T> |
|
FlowableOnErrorNext<T> |
|
FlowableOnErrorNext.OnErrorNextSubscriber<T> |
|
FlowableOnErrorReturn<T> |
|
FlowableOnErrorReturn.OnErrorReturnSubscriber<T> |
|
FlowableOnSubscribe<T> |
A functional interface that has a subscribe() method that receives
a FlowableEmitter instance that allows pushing
events in a backpressure-safe and cancellation-safe manner.
|
FlowableOperator<Downstream,Upstream> |
Interface to map/wrap a downstream Subscriber to an upstream Subscriber .
|
FlowableProcessor<T> |
Represents a Subscriber and a Flowable (Publisher) at the same time, allowing
multicasting events from a single source to multiple child Subscribers.
|
FlowablePublish<T> |
Shares a single underlying connection to the upstream Publisher
and multicasts events to all subscribed subscribers until the upstream
completes or the connection is disposed.
|
FlowablePublish.InnerSubscription<T> |
|
FlowablePublish.PublishConnection<T> |
|
FlowablePublishMulticast<T,R> |
Multicasts a Flowable over a selector function.
|
FlowablePublishMulticast.MulticastProcessor<T> |
|
FlowablePublishMulticast.MulticastSubscription<T> |
|
FlowablePublishMulticast.OutputCanceller<R> |
|
FlowableRange |
Emits a range of integer values.
|
FlowableRange.BaseRangeSubscription |
|
FlowableRange.RangeConditionalSubscription |
|
FlowableRange.RangeSubscription |
|
FlowableRangeLong |
Emits a range of long values.
|
FlowableRangeLong.BaseRangeSubscription |
|
FlowableRangeLong.RangeConditionalSubscription |
|
FlowableRangeLong.RangeSubscription |
|
FlowableReduce<T> |
Reduces a sequence via a function into a single value or signals NoSuchElementException for
an empty source.
|
FlowableReduce.ReduceSubscriber<T> |
|
FlowableReduceMaybe<T> |
Reduce a Flowable into a single value exposed as Single or signal NoSuchElementException.
|
FlowableReduceMaybe.ReduceSubscriber<T> |
|
FlowableReduceSeedSingle<T,R> |
Reduce a sequence of values, starting from a seed value and by using
an accumulator function and return the last accumulated value.
|
FlowableReduceSeedSingle.ReduceSeedObserver<T,R> |
|
FlowableReduceWithSingle<T,R> |
Reduce a sequence of values, starting from a generated seed value and by using
an accumulator function and return the last accumulated value.
|
FlowableRefCount<T> |
Returns an observable sequence that stays connected to the source as long as
there is at least one subscription to the observable sequence.
|
FlowableRefCount.RefConnection |
|
FlowableRefCount.RefCountSubscriber<T> |
|
FlowableRepeat<T> |
|
FlowableRepeat.RepeatSubscriber<T> |
|
FlowableRepeatUntil<T> |
|
FlowableRepeatUntil.RepeatSubscriber<T> |
|
FlowableRepeatWhen<T> |
|
FlowableRepeatWhen.RepeatWhenSubscriber<T> |
|
FlowableRepeatWhen.WhenReceiver<T,U> |
|
FlowableRepeatWhen.WhenSourceSubscriber<T,U> |
|
FlowableReplay<T> |
|
FlowableReplay.BoundedReplayBuffer<T> |
Base class for bounded buffering with options to specify an
enter and leave transforms and custom truncation behavior.
|
FlowableReplay.DefaultUnboundedFactory |
|
FlowableReplay.InnerSubscription<T> |
A Subscription that manages the request and cancellation state of a
child subscriber in thread-safe manner.
|
FlowableReplay.MulticastFlowable<R,U> |
|
FlowableReplay.Node |
Represents a node in a bounded replay buffer's linked list.
|
FlowableReplay.ReplayBuffer<T> |
The interface for interacting with various buffering logic.
|
FlowableReplay.ReplayBufferSupplier<T> |
|
FlowableReplay.ReplayPublisher<T> |
|
FlowableReplay.ReplaySubscriber<T> |
|
FlowableReplay.ScheduledReplayBufferSupplier<T> |
|
FlowableReplay.SizeAndTimeBoundReplayBuffer<T> |
Size and time bound replay buffer.
|
FlowableReplay.SizeBoundReplayBuffer<T> |
A bounded replay buffer implementation with size limit only.
|
FlowableReplay.UnboundedReplayBuffer<T> |
Holds an unbounded list of events.
|
FlowableRetryBiPredicate<T> |
|
FlowableRetryBiPredicate.RetryBiSubscriber<T> |
|
FlowableRetryPredicate<T> |
|
FlowableRetryPredicate.RetrySubscriber<T> |
|
FlowableRetryWhen<T> |
|
FlowableRetryWhen.RetryWhenSubscriber<T> |
|
FlowableSamplePublisher<T> |
|
FlowableSamplePublisher.SampleMainEmitLast<T> |
|
FlowableSamplePublisher.SampleMainNoLast<T> |
|
FlowableSamplePublisher.SamplePublisherSubscriber<T> |
|
FlowableSamplePublisher.SamplerSubscriber<T> |
|
FlowableSampleTimed<T> |
|
FlowableSampleTimed.SampleTimedEmitLast<T> |
|
FlowableSampleTimed.SampleTimedNoLast<T> |
|
FlowableSampleTimed.SampleTimedSubscriber<T> |
|
FlowableScalarXMap |
Utility classes to work with scalar-sourced XMap operators (where X == { flat, concat, switch }).
|
FlowableScalarXMap.ScalarXMapFlowable<T,R> |
Maps a scalar value to a Publisher and subscribes to it.
|
FlowableScan<T> |
|
FlowableScan.ScanSubscriber<T> |
|
FlowableScanSeed<T,R> |
|
FlowableScanSeed.ScanSeedSubscriber<T,R> |
|
FlowableSequenceEqual<T> |
|
FlowableSequenceEqual.EqualCoordinator<T> |
|
FlowableSequenceEqual.EqualCoordinatorHelper |
Provides callbacks for the EqualSubscribers.
|
FlowableSequenceEqual.EqualSubscriber<T> |
|
FlowableSequenceEqualSingle<T> |
|
FlowableSequenceEqualSingle.EqualCoordinator<T> |
|
FlowableSerialized<T> |
|
FlowableSingle<T> |
|
FlowableSingle.SingleElementSubscriber<T> |
|
FlowableSingleMaybe<T> |
|
FlowableSingleMaybe.SingleElementSubscriber<T> |
|
FlowableSingleSingle<T> |
|
FlowableSingleSingle.SingleElementSubscriber<T> |
|
FlowableSingleStageSubscriber<T> |
Signals the only element of the source via the underlying CompletableFuture,
signals the a default item if the upstream is empty or signals IllegalArgumentException
if the upstream has more than one item.
|
FlowableSkip<T> |
|
FlowableSkip.SkipSubscriber<T> |
|
FlowableSkipLast<T> |
|
FlowableSkipLast.SkipLastSubscriber<T> |
|
FlowableSkipLastTimed<T> |
|
FlowableSkipLastTimed.SkipLastTimedSubscriber<T> |
|
FlowableSkipUntil<T,U> |
|
FlowableSkipUntil.SkipUntilMainSubscriber<T> |
|
FlowableSkipWhile<T> |
|
FlowableSkipWhile.SkipWhileSubscriber<T> |
|
FlowableStageSubscriber<T> |
Base class that extends CompletableFuture and provides basic infrastructure
to notify watchers upon upstream signals.
|
FlowableSubscribeOn<T> |
Subscribes to the source Flowable on the specified Scheduler and makes
sure downstream requests are scheduled there as well.
|
FlowableSubscribeOn.SubscribeOnSubscriber<T> |
|
FlowableSubscribeOn.SubscribeOnSubscriber.Request |
|
FlowableSubscriber<T> |
Represents a Reactive-Streams inspired Subscriber that is RxJava 3 only
and weakens the Reactive Streams rules §1.3
and §3.9 of the specification
for gaining performance.
|
FlowableSwitchIfEmpty<T> |
|
FlowableSwitchIfEmpty.SwitchIfEmptySubscriber<T> |
|
FlowableSwitchMap<T,R> |
|
FlowableSwitchMap.SwitchMapInnerSubscriber<T,R> |
|
FlowableSwitchMap.SwitchMapSubscriber<T,R> |
|
FlowableSwitchMapCompletable<T> |
Maps the upstream values into CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running.
|
FlowableSwitchMapCompletable.SwitchMapCompletableObserver<T> |
|
FlowableSwitchMapCompletable.SwitchMapCompletableObserver.SwitchMapInnerObserver |
|
FlowableSwitchMapCompletablePublisher<T> |
|
FlowableSwitchMapMaybe<T,R> |
Maps the upstream items into MaybeSource s and switches (subscribes) to the newer ones
while disposing the older ones and emits the latest success value if available, optionally delaying
errors from the main source or the inner sources.
|
FlowableSwitchMapMaybe.SwitchMapMaybeSubscriber<T,R> |
|
FlowableSwitchMapMaybe.SwitchMapMaybeSubscriber.SwitchMapMaybeObserver<R> |
|
FlowableSwitchMapMaybePublisher<T,R> |
Switch between subsequent MaybeSource s emitted by a Publisher .
|
FlowableSwitchMapSingle<T,R> |
Maps the upstream items into SingleSource s and switches (subscribes) to the newer ones
while disposing the older ones and emits the latest success value, optionally delaying
errors from the main source or the inner sources.
|
FlowableSwitchMapSingle.SwitchMapSingleSubscriber<T,R> |
|
FlowableSwitchMapSingle.SwitchMapSingleSubscriber.SwitchMapSingleObserver<R> |
|
FlowableSwitchMapSinglePublisher<T,R> |
Switch between subsequent SingleSource s emitted by a Publisher .
|
FlowableTake<T> |
|
FlowableTake.TakeSubscriber<T> |
|
FlowableTakeLast<T> |
|
FlowableTakeLast.TakeLastSubscriber<T> |
|
FlowableTakeLastOne<T> |
|
FlowableTakeLastOne.TakeLastOneSubscriber<T> |
|
FlowableTakeLastTimed<T> |
|
FlowableTakeLastTimed.TakeLastTimedSubscriber<T> |
|
FlowableTakePublisher<T> |
Take with a generic Publisher source.
|
FlowableTakeUntil<T,U> |
|
FlowableTakeUntil.TakeUntilMainSubscriber<T> |
|
FlowableTakeUntilPredicate<T> |
|
FlowableTakeUntilPredicate.InnerSubscriber<T> |
|
FlowableTakeWhile<T> |
|
FlowableTakeWhile.TakeWhileSubscriber<T> |
|
FlowableThrottleFirstTimed<T> |
|
FlowableThrottleFirstTimed.DebounceTimedSubscriber<T> |
|
FlowableThrottleLatest<T> |
Emits the next or latest item when the given time elapses.
|
FlowableThrottleLatest.ThrottleLatestSubscriber<T> |
|
FlowableTimeInterval<T> |
|
FlowableTimeInterval.TimeIntervalSubscriber<T> |
|
FlowableTimeout<T,U,V> |
|
FlowableTimeout.TimeoutConsumer |
|
FlowableTimeout.TimeoutFallbackSubscriber<T> |
|
FlowableTimeout.TimeoutSelectorSupport |
|
FlowableTimeout.TimeoutSubscriber<T> |
|
FlowableTimeoutTimed<T> |
|
FlowableTimeoutTimed.FallbackSubscriber<T> |
|
FlowableTimeoutTimed.TimeoutFallbackSubscriber<T> |
|
FlowableTimeoutTimed.TimeoutSubscriber<T> |
|
FlowableTimeoutTimed.TimeoutSupport |
|
FlowableTimeoutTimed.TimeoutTask |
|
FlowableTimer |
|
FlowableTimer.TimerSubscriber |
|
FlowableToList<T,U extends java.util.Collection<? super T>> |
|
FlowableToList.ToListSubscriber<T,U extends java.util.Collection<? super T>> |
|
FlowableToListSingle<T,U extends java.util.Collection<? super T>> |
|
FlowableToListSingle.ToListSubscriber<T,U extends java.util.Collection<? super T>> |
|
FlowableTransformer<Upstream,Downstream> |
|
FlowableUnsubscribeOn<T> |
|
FlowableUnsubscribeOn.UnsubscribeSubscriber<T> |
|
FlowableUsing<T,D> |
|
FlowableUsing.UsingSubscriber<T,D> |
|
FlowableWindow<T> |
|
FlowableWindow.WindowExactSubscriber<T> |
|
FlowableWindow.WindowOverlapSubscriber<T> |
|
FlowableWindow.WindowSkipSubscriber<T> |
|
FlowableWindowBoundary<T,B> |
|
FlowableWindowBoundary.WindowBoundaryInnerSubscriber<T,B> |
|
FlowableWindowBoundary.WindowBoundaryMainSubscriber<T,B> |
|
FlowableWindowBoundarySelector<T,B,V> |
|
FlowableWindowBoundarySelector.WindowBoundaryMainSubscriber<T,B,V> |
|
FlowableWindowBoundarySelector.WindowBoundaryMainSubscriber.WindowEndSubscriberIntercept<T,V> |
|
FlowableWindowBoundarySelector.WindowBoundaryMainSubscriber.WindowStartItem<B> |
|
FlowableWindowBoundarySelector.WindowBoundaryMainSubscriber.WindowStartSubscriber<B> |
|
FlowableWindowSubscribeIntercept<T> |
Wrapper for a FlowableProcessor that detects an incoming subscriber.
|
FlowableWindowTimed<T> |
|
FlowableWindowTimed.AbstractWindowSubscriber<T> |
|
FlowableWindowTimed.WindowExactBoundedSubscriber<T> |
|
FlowableWindowTimed.WindowExactBoundedSubscriber.WindowBoundaryRunnable |
|
FlowableWindowTimed.WindowExactUnboundedSubscriber<T> |
|
FlowableWindowTimed.WindowSkipSubscriber<T> |
|
FlowableWindowTimed.WindowSkipSubscriber.WindowBoundaryRunnable |
|
FlowableWithLatestFrom<T,U,R> |
|
FlowableWithLatestFrom.WithLatestFromSubscriber<T,U,R> |
|
FlowableWithLatestFromMany<T,R> |
Combines a main sequence of values with the latest from multiple other sequences via
a selector function.
|
FlowableWithLatestFromMany.WithLatestFromSubscriber<T,R> |
|
FlowableWithLatestFromMany.WithLatestInnerSubscriber |
|
FlowableZip<T,R> |
|
FlowableZip.ZipCoordinator<T,R> |
|
FlowableZip.ZipSubscriber<T,R> |
|
FlowableZipIterable<T,U,V> |
|
FlowableZipIterable.ZipIterableSubscriber<T,U,V> |
|
ForEachWhileObserver<T> |
|
ForEachWhileSubscriber<T> |
|
Function<T,R> |
A functional interface that takes a value and returns another value, possibly with a
different type and allows throwing a checked exception.
|
Function3<T1,T2,T3,R> |
A functional interface (callback) that computes a value based on multiple input values.
|
Function4<T1,T2,T3,T4,R> |
A functional interface (callback) that computes a value based on multiple input values.
|
Function5<T1,T2,T3,T4,T5,R> |
A functional interface (callback) that computes a value based on multiple input values.
|
Function6<T1,T2,T3,T4,T5,T6,R> |
A functional interface (callback) that computes a value based on multiple input values.
|
Function7<T1,T2,T3,T4,T5,T6,T7,R> |
A functional interface (callback) that computes a value based on multiple input values.
|
Function8<T1,T2,T3,T4,T5,T6,T7,T8,R> |
A functional interface (callback) that computes a value based on multiple input values.
|
Function9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> |
A functional interface (callback) that computes a value based on multiple input values.
|
Functions |
Utility methods to convert the BiFunction, Function3..Function9 instances to Function of Object array.
|
Functions.ActionConsumer<T> |
|
Functions.Array2Func<T1,T2,R> |
|
Functions.Array3Func<T1,T2,T3,R> |
|
Functions.Array4Func<T1,T2,T3,T4,R> |
|
Functions.Array5Func<T1,T2,T3,T4,T5,R> |
|
Functions.Array6Func<T1,T2,T3,T4,T5,T6,R> |
|
Functions.Array7Func<T1,T2,T3,T4,T5,T6,T7,R> |
|
Functions.Array8Func<T1,T2,T3,T4,T5,T6,T7,T8,R> |
|
Functions.Array9Func<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> |
|
Functions.ArrayListCapacityCallable<T> |
|
Functions.BooleanSupplierPredicateReverse<T> |
|
Functions.BoundedConsumer |
|
Functions.CastToClass<T,U> |
|
Functions.ClassFilter<T,U> |
|
Functions.EmptyAction |
|
Functions.EmptyConsumer |
|
Functions.EmptyLongConsumer |
|
Functions.EmptyRunnable |
|
Functions.EqualsPredicate<T> |
|
Functions.ErrorConsumer |
|
Functions.FalsePredicate |
|
Functions.FutureAction |
|
Functions.HashSetSupplier |
|
Functions.Identity |
|
Functions.JustValue<T,U> |
|
Functions.ListSorter<T> |
|
Functions.MaxRequestSubscription |
|
Functions.NaturalComparator |
|
Functions.NotificationOnComplete<T> |
|
Functions.NotificationOnError<T> |
|
Functions.NotificationOnNext<T> |
|
Functions.NullProvider |
|
Functions.OnErrorMissingConsumer |
|
Functions.TimestampFunction<T> |
|
Functions.ToMapKeySelector<K,T> |
|
Functions.ToMapKeyValueSelector<K,V,T> |
|
Functions.ToMultimapKeyValueSelector<K,V,T> |
|
Functions.TruePredicate |
|
FuseToFlowable<T> |
Interface indicating a operator implementation can be macro-fused back to Flowable in case
the operator goes from Flowable to some other reactive type and then the sequence calls
for toFlowable again:
|
FuseToMaybe<T> |
Interface indicating an operator implementation can be macro-fused back to Maybe in case
the operator goes from Maybe to some other reactive type and then the sequence calls
for toMaybe again:
|
FuseToObservable<T> |
Interface indicating a operator implementation can be macro-fused back to Observable in case
the operator goes from Observable to some other reactive type and then the sequence calls
for toObservable again:
|
FutureDisposable |
A Disposable container that cancels a Future instance.
|
FutureMultiObserver<T> |
An Observer + Future that expects exactly one upstream value and provides it
via the (blocking) Future API.
|
FutureObserver<T> |
An Observer + Future that expects exactly one upstream value and provides it
via the (blocking) Future API.
|
FutureSubscriber<T> |
A Subscriber + Future that expects exactly one upstream value and provides it
via the (blocking) Future API.
|
GroupedFlowable<K,T> |
|
GroupedObservable<K,T> |
|
HalfSerializer |
Utility methods to perform half-serialization: a form of serialization
where onNext is guaranteed to be called from a single thread but
onError or onComplete may be called from any threads.
|
HashMapSupplier |
|
HasUpstreamCompletableSource |
|
HasUpstreamMaybeSource<T> |
|
HasUpstreamObservableSource<T> |
|
HasUpstreamPublisher<T> |
|
HasUpstreamSingleSource<T> |
|
ImmediateThinScheduler |
A Scheduler partially implementing the API by allowing only non-delayed, non-periodic
task execution on the current thread immediately.
|
ImmediateThinScheduler.ImmediateThinWorker |
|
InnerQueuedObserver<T> |
Subscriber that can fuse with the upstream and calls a support interface
whenever an event is available.
|
InnerQueuedObserverSupport<T> |
Interface to allow the InnerQueuedSubscriber to call back a parent
with signals.
|
InnerQueuedSubscriber<T> |
Subscriber that can fuse with the upstream and calls a support interface
whenever an event is available.
|
InnerQueuedSubscriberSupport<T> |
Interface to allow the InnerQueuedSubscriber to call back a parent
with signals.
|
InstantPeriodicTask |
Wrapper for a regular task that gets immediately rescheduled when the task completed.
|
IntFunction<T> |
A functional interface (callback) that takes a primitive value and return value of type T.
|
IoScheduler |
Scheduler that creates and caches a set of thread pools and reuses them if possible.
|
IoScheduler.CachedWorkerPool |
|
IoScheduler.EventLoopWorker |
|
IoScheduler.ThreadWorker |
|
LambdaConsumerIntrospection |
An interface that indicates that the implementing type is composed of individual components and exposes information
about their behavior.
|
LambdaObserver<T> |
|
LambdaSubscriber<T> |
|
LinkedArrayList |
A list implementation which combines an ArrayList with a LinkedList to
avoid copying values when the capacity needs to be increased.
|
ListAddBiConsumer |
|
ListCompositeDisposable |
A disposable container that can hold onto multiple other disposables.
|
LongConsumer |
A functional interface (callback) that consumes a primitive long value.
|
MaterializeSingleObserver<T> |
A consumer that implements the consumer types of Maybe, Single and Completable
and turns their signals into Notifications for a SingleObserver.
|
Maybe<T> |
The Maybe class represents a deferred computation and emission of a single value, no value at all or an exception.
|
MaybeAmb<T> |
Signals the event of the first MaybeSource that signals.
|
MaybeAmb.AmbMaybeObserver<T> |
|
MaybeCache<T> |
Consumes the source once and replays its signal to any current or future MaybeObservers.
|
MaybeCache.CacheDisposable<T> |
|
MaybeCallbackObserver<T> |
MaybeObserver that delegates the onSuccess, onError and onComplete method calls to callbacks.
|
MaybeConcatArray<T> |
Concatenate values of each MaybeSource provided in an array.
|
MaybeConcatArray.ConcatMaybeObserver<T> |
|
MaybeConcatArrayDelayError<T> |
Concatenate values of each MaybeSource provided in an array and delays
any errors till the very end.
|
MaybeConcatArrayDelayError.ConcatMaybeObserver<T> |
|
MaybeConcatIterable<T> |
Concatenate values of each MaybeSource provided by an Iterable.
|
MaybeConcatIterable.ConcatMaybeObserver<T> |
|
MaybeContains<T> |
Signals true if the source signals a value that is object-equals with the provided
value, false otherwise or for empty sources.
|
MaybeContains.ContainsMaybeObserver |
|
MaybeConverter<T,R> |
|
MaybeCount<T> |
Signals 1L if the source signalled an item or 0L if the source is empty.
|
MaybeCount.CountMaybeObserver |
|
MaybeCreate<T> |
Provides an API over MaybeObserver that serializes calls to onXXX and manages cancellation
in a safe manner.
|
MaybeCreate.Emitter<T> |
|
MaybeDefer<T> |
Defers the creation of the actual Maybe the incoming MaybeObserver is subscribed to.
|
MaybeDelay<T> |
Delays all signal types by the given amount and re-emits them on the given scheduler.
|
MaybeDelay.DelayMaybeObserver<T> |
|
MaybeDelayOtherPublisher<T,U> |
Delay the emission of the main signal until the other signals an item or completes.
|
MaybeDelayOtherPublisher.DelayMaybeObserver<T,U> |
|
MaybeDelayOtherPublisher.OtherSubscriber<T> |
|
MaybeDelaySubscriptionOtherPublisher<T,U> |
Delay the subscription to the main Maybe until the other signals an item or completes.
|
MaybeDelaySubscriptionOtherPublisher.DelayMaybeObserver<T> |
|
MaybeDelaySubscriptionOtherPublisher.OtherSubscriber<T> |
|
MaybeDelayWithCompletable<T> |
|
MaybeDelayWithCompletable.DelayWithMainObserver<T> |
|
MaybeDelayWithCompletable.OtherObserver<T> |
|
MaybeDematerialize<T,R> |
Maps the success value of the source to a Notification, then
maps it back to the corresponding signal type.
|
MaybeDematerialize.DematerializeObserver<T,R> |
|
MaybeDetach<T> |
Breaks the references between the upstream and downstream when the Maybe terminates.
|
MaybeDetach.DetachMaybeObserver<T> |
|
MaybeDoAfterSuccess<T> |
Calls a consumer after pushing the current item to the downstream.
|
MaybeDoAfterSuccess.DoAfterObserver<T> |
|
MaybeDoFinally<T> |
Execute an action after an onSuccess, onError, onComplete or a dispose event.
|
MaybeDoFinally.DoFinallyObserver<T> |
|
MaybeDoOnEvent<T> |
Calls a BiConsumer with the success, error values of the upstream Maybe or with two nulls if
the Maybe completed.
|
MaybeDoOnEvent.DoOnEventMaybeObserver<T> |
|
MaybeDoOnLifecycle<T> |
Invokes callbacks upon onSubscribe from upstream and
dispose from downstream.
|
MaybeDoOnLifecycle.MaybeLifecycleObserver<T> |
|
MaybeDoOnTerminate<T> |
|
MaybeEmitter<T> |
Abstraction over an RxJava MaybeObserver that allows associating
a resource with it.
|
MaybeEmpty |
Signals an onComplete.
|
MaybeEqualSingle<T> |
Compares two MaybeSources to see if they are both empty or emit the same value compared
via a BiPredicate.
|
MaybeEqualSingle.EqualCoordinator<T> |
|
MaybeEqualSingle.EqualObserver<T> |
|
MaybeError<T> |
Signals a constant Throwable.
|
MaybeErrorCallable<T> |
Signals a Throwable returned by a Supplier.
|
MaybeFilter<T> |
Filters the upstream via a predicate, returning the success item or completing if
the predicate returns false.
|
MaybeFilter.FilterMaybeObserver<T> |
|
MaybeFilterSingle<T> |
Filters the upstream SingleSource via a predicate, returning the success item or completing if
the predicate returns false.
|
MaybeFilterSingle.FilterMaybeObserver<T> |
|
MaybeFlatMapBiSelector<T,U,R> |
Maps a source item to another MaybeSource then calls a BiFunction with the
original item and the secondary item to generate the final result.
|
MaybeFlatMapBiSelector.FlatMapBiMainObserver<T,U,R> |
|
MaybeFlatMapBiSelector.FlatMapBiMainObserver.InnerObserver<T,U,R> |
|
MaybeFlatMapCompletable<T> |
Maps the success value of the source MaybeSource into a Completable.
|
MaybeFlatMapCompletable.FlatMapCompletableObserver<T> |
|
MaybeFlatMapIterableFlowable<T,R> |
Maps a success value into an Iterable and streams it back as a Flowable.
|
MaybeFlatMapIterableFlowable.FlatMapIterableObserver<T,R> |
|
MaybeFlatMapIterableObservable<T,R> |
Maps a success value into an Iterable and streams it back as a Flowable.
|
MaybeFlatMapIterableObservable.FlatMapIterableObserver<T,R> |
|
MaybeFlatMapNotification<T,R> |
Maps a value into a MaybeSource and relays its signal.
|
MaybeFlatMapNotification.FlatMapMaybeObserver<T,R> |
|
MaybeFlatMapObservable<T,R> |
Maps the success value of a Maybe onto an ObservableSource and
relays its signals to the downstream observer.
|
MaybeFlatMapObservable.FlatMapObserver<T,R> |
|
MaybeFlatMapPublisher<T,R> |
Maps the success value of a Maybe onto a Publisher and
relays its signals to the downstream subscriber.
|
MaybeFlatMapPublisher.FlatMapPublisherSubscriber<T,R> |
|
MaybeFlatMapSingle<T,R> |
Maps the success value of the source MaybeSource into a Single.
|
MaybeFlatMapSingle.FlatMapMaybeObserver<T,R> |
|
MaybeFlatMapSingle.FlatMapSingleObserver<R> |
|
MaybeFlatten<T,R> |
Maps a value into a MaybeSource and relays its signal.
|
MaybeFlatten.FlatMapMaybeObserver<T,R> |
|
MaybeFlattenStreamAsFlowable<T,R> |
Map the success value into a Java Stream and emits its values.
|
MaybeFlattenStreamAsFlowable.FlattenStreamMultiObserver<T,R> |
|
MaybeFlattenStreamAsObservable<T,R> |
Map the success value into a Java Stream and emits its values.
|
MaybeFlattenStreamAsObservable.FlattenStreamMultiObserver<T,R> |
|
MaybeFromAction<T> |
Executes an Action and signals its exception or completes normally.
|
MaybeFromCallable<T> |
Executes a callable and signals its value as success or signals an exception.
|
MaybeFromCompletable<T> |
Wrap a Completable into a Maybe.
|
MaybeFromCompletable.FromCompletableObserver<T> |
|
MaybeFromCompletionStage<T> |
Wrap a CompletionStage and signal its outcome.
|
MaybeFromCompletionStage.CompletionStageHandler<T> |
|
MaybeFromFuture<T> |
Waits until the source Future completes or the wait times out; treats a null
result as indication to signal onComplete instead of onSuccess .
|
MaybeFromRunnable<T> |
Executes an Runnable and signals its exception or completes normally.
|
MaybeFromSingle<T> |
Wrap a Single into a Maybe.
|
MaybeFromSingle.FromSingleObserver<T> |
|
MaybeFromSupplier<T> |
Executes a supplier and signals its value as success or signals an exception.
|
MaybeHide<T> |
Hides the identity of the upstream Maybe and its Disposable sent through onSubscribe.
|
MaybeHide.HideMaybeObserver<T> |
|
MaybeIgnoreElement<T> |
Turns an onSuccess into an onComplete, onError and onComplete is relayed as is.
|
MaybeIgnoreElement.IgnoreMaybeObserver<T> |
|
MaybeIgnoreElementCompletable<T> |
Turns an onSuccess into an onComplete, onError and onComplete is relayed as is.
|
MaybeIgnoreElementCompletable.IgnoreMaybeObserver<T> |
|
MaybeIsEmpty<T> |
Signals true if the source Maybe signals onComplete, signals false if the source Maybe
signals onSuccess.
|
MaybeIsEmpty.IsEmptyMaybeObserver<T> |
|
MaybeIsEmptySingle<T> |
Signals true if the source Maybe signals onComplete, signals false if the source Maybe
signals onSuccess.
|
MaybeIsEmptySingle.IsEmptyMaybeObserver<T> |
|
MaybeJust<T> |
Signals a constant value.
|
MaybeLift<T,R> |
Calls a MaybeOperator for the incoming MaybeObserver.
|
MaybeMap<T,R> |
Maps the upstream success value into some other value.
|
MaybeMap.MapMaybeObserver<T,R> |
|
MaybeMapOptional<T,R> |
Maps the success value to an Optional and emits its non-empty value or completes.
|
MaybeMapOptional.MapOptionalMaybeObserver<T,R> |
|
MaybeMaterialize<T> |
Turn the signal types of a Maybe source into a single Notification of
equal kind.
|
MaybeMergeArray<T> |
Run all MaybeSources of an array at once and signal their values as they become available.
|
MaybeMergeArray.ClqSimpleQueue<T> |
|
MaybeMergeArray.MergeMaybeObserver<T> |
|
MaybeMergeArray.MpscFillOnceSimpleQueue<T> |
|
MaybeMergeArray.SimpleQueueWithConsumerIndex<T> |
|
MaybeNever |
Doesn't signal any event other than onSubscribe.
|
MaybeObserveOn<T> |
Signals the onSuccess, onError or onComplete events on a the specific scheduler.
|
MaybeObserveOn.ObserveOnMaybeObserver<T> |
|
MaybeObserver<T> |
Provides a mechanism for receiving push-based notification of a single value, an error or completion without any value.
|
MaybeOnErrorComplete<T> |
Emits an onComplete if the source emits an onError and the predicate returns true for
that Throwable.
|
MaybeOnErrorComplete.OnErrorCompleteMultiObserver<T> |
|
MaybeOnErrorNext<T> |
Subscribes to the MaybeSource returned by a function if the main source signals an onError.
|
MaybeOnErrorNext.OnErrorNextMaybeObserver<T> |
|
MaybeOnErrorNext.OnErrorNextMaybeObserver.NextMaybeObserver<T> |
|
MaybeOnErrorReturn<T> |
Returns a value generated via a function if the main source signals an onError.
|
MaybeOnErrorReturn.OnErrorReturnMaybeObserver<T> |
|
MaybeOnSubscribe<T> |
A functional interface that has a subscribe() method that receives
a MaybeEmitter instance that allows pushing
an event in a cancellation-safe manner.
|
MaybeOperator<Downstream,Upstream> |
Interface to map/wrap a downstream MaybeObserver to an upstream MaybeObserver .
|
MaybePeek<T> |
Peeks into the lifecycle of a Maybe and MaybeObserver.
|
MaybePeek.MaybePeekObserver<T> |
|
MaybeSource<T> |
|
MaybeSubject<T> |
Represents a hot Maybe-like source and consumer of events similar to Subjects.
|
MaybeSubject.MaybeDisposable<T> |
|
MaybeSubscribeOn<T> |
Subscribes to the upstream MaybeSource on the specified scheduler.
|
MaybeSubscribeOn.SubscribeOnMaybeObserver<T> |
|
MaybeSubscribeOn.SubscribeTask<T> |
|
MaybeSwitchIfEmpty<T> |
Subscribes to the other source if the main source is empty.
|
MaybeSwitchIfEmpty.SwitchIfEmptyMaybeObserver<T> |
|
MaybeSwitchIfEmpty.SwitchIfEmptyMaybeObserver.OtherMaybeObserver<T> |
|
MaybeSwitchIfEmptySingle<T> |
Subscribes to the other source if the main source is empty.
|
MaybeSwitchIfEmptySingle.SwitchIfEmptyMaybeObserver<T> |
|
MaybeSwitchIfEmptySingle.SwitchIfEmptyMaybeObserver.OtherSingleObserver<T> |
|
MaybeTakeUntilMaybe<T,U> |
Relays the main source's event unless the other Maybe signals an item first or just completes
at which point the resulting Maybe is completed.
|
MaybeTakeUntilMaybe.TakeUntilMainMaybeObserver<T,U> |
|
MaybeTakeUntilMaybe.TakeUntilMainMaybeObserver.TakeUntilOtherMaybeObserver<U> |
|
MaybeTakeUntilPublisher<T,U> |
Relays the main source's event unless the other Publisher signals an item first or just completes
at which point the resulting Maybe is completed.
|
MaybeTakeUntilPublisher.TakeUntilMainMaybeObserver<T,U> |
|
MaybeTakeUntilPublisher.TakeUntilMainMaybeObserver.TakeUntilOtherMaybeObserver<U> |
|
MaybeTimeInterval<T> |
Measures the time between subscription and the success item emission
from the upstream and emits this as a Timed success value.
|
MaybeTimeInterval.TimeIntervalMaybeObserver<T> |
|
MaybeTimeoutMaybe<T,U> |
Switches to the fallback Maybe if the other MaybeSource signals a success or completes, or
signals TimeoutException if fallback is null.
|
MaybeTimeoutMaybe.TimeoutFallbackMaybeObserver<T> |
|
MaybeTimeoutMaybe.TimeoutMainMaybeObserver<T,U> |
|
MaybeTimeoutMaybe.TimeoutOtherMaybeObserver<T,U> |
|
MaybeTimeoutPublisher<T,U> |
Switches to the fallback Maybe if the other Publisher signals a success or completes, or
signals TimeoutException if fallback is null.
|
MaybeTimeoutPublisher.TimeoutFallbackMaybeObserver<T> |
|
MaybeTimeoutPublisher.TimeoutMainMaybeObserver<T,U> |
|
MaybeTimeoutPublisher.TimeoutOtherMaybeObserver<T,U> |
|
MaybeTimer |
Signals a 0L after the specified delay.
|
MaybeTimer.TimerDisposable |
|
MaybeToFlowable<T> |
Wraps a MaybeSource and exposes it as a Flowable, relaying signals in a backpressure-aware manner
and composes cancellation through.
|
MaybeToFlowable.MaybeToFlowableSubscriber<T> |
|
MaybeToObservable<T> |
Wraps a MaybeSource and exposes it as an Observable, relaying signals in a backpressure-aware manner
and composes cancellation through.
|
MaybeToObservable.MaybeToObservableObserver<T> |
|
MaybeToPublisher |
Helper function to merge/concat values of each MaybeSource provided by a Publisher.
|
MaybeToSingle<T> |
Wraps a MaybeSource and exposes its onSuccess and onError signals and signals
NoSuchElementException for onComplete if defaultValue is null.
|
MaybeToSingle.ToSingleMaybeSubscriber<T> |
|
MaybeTransformer<Upstream,Downstream> |
Interface to compose Maybe s.
|
MaybeUnsafeCreate<T> |
Wraps a MaybeSource without safeguard and calls its subscribe() method for each MaybeObserver.
|
MaybeUnsubscribeOn<T> |
Makes sure a dispose() call from downstream happens on the specified scheduler.
|
MaybeUnsubscribeOn.UnsubscribeOnMaybeObserver<T> |
|
MaybeUsing<T,D> |
Creates a resource and a dependent Maybe for each incoming Observer and optionally
disposes the resource eagerly (before the terminal event is send out).
|
MaybeUsing.UsingObserver<T,D> |
|
MaybeZipArray<T,R> |
|
MaybeZipArray.ZipCoordinator<T,R> |
|
MaybeZipArray.ZipMaybeObserver<T> |
|
MaybeZipIterable<T,R> |
|
MergerBiFunction<T> |
A BiFunction that merges two Lists into a new list.
|
MissingBackpressureException |
Indicates that an operator attempted to emit a value but the downstream wasn't ready for it.
|
MpscLinkedQueue<T> |
A multi-producer single consumer unbounded queue.
|
MpscLinkedQueue.LinkedQueueNode<E> |
|
MulticastProcessor<T> |
A FlowableProcessor implementation that coordinates downstream requests through
a front-buffer and stable-prefetching, optionally canceling the upstream if all
subscribers have cancelled.
|
MulticastProcessor.MulticastSubscription<T> |
|
NewThreadScheduler |
Schedules work on a new thread.
|
NewThreadWorker |
Base class that manages a single-threaded ScheduledExecutorService as a
worker but doesn't perform task-tracking operations.
|
NonBlockingThread |
Marker interface to indicate blocking is not recommended while running
on a Scheduler with a thread type implementing it.
|
NonNull |
Indicates that a field/parameter/variable/type parameter/return type is never null.
|
Notification<T> |
Represents the reactive signal types: onNext , onError and onComplete and
holds their parameter values (a value, a Throwable , nothing).
|
NotificationLite |
Lightweight notification handling utility class.
|
NotificationLite.DisposableNotification |
Wraps a Disposable.
|
NotificationLite.ErrorNotification |
Wraps a Throwable.
|
NotificationLite.SubscriptionNotification |
Wraps a Subscription.
|
Nullable |
Indicates that a field/parameter/variable/type parameter/return type may be null.
|
ObjectHelper |
Utility methods containing the backport of Java 7's Objects utility class.
|
ObjectHelper.BiObjectPredicate |
|
Observable<T> |
The Observable class is the non-backpressured, optionally multi-valued base reactive class that
offers factory methods, intermediate operators and the ability to consume synchronous
and/or asynchronous reactive dataflows.
|
ObservableAll<T> |
|
ObservableAll.AllObserver<T> |
|
ObservableAllSingle<T> |
|
ObservableAllSingle.AllObserver<T> |
|
ObservableAmb<T> |
|
ObservableAmb.AmbCoordinator<T> |
|
ObservableAmb.AmbInnerObserver<T> |
|
ObservableAny<T> |
|
ObservableAny.AnyObserver<T> |
|
ObservableAnySingle<T> |
|
ObservableAnySingle.AnyObserver<T> |
|
ObservableAutoConnect<T> |
Wraps a ConnectableObservable and calls its connect() method once
the specified number of Observers have subscribed.
|
ObservableBlockingSubscribe |
Utility methods to consume an Observable in a blocking manner with callbacks or Observer.
|
ObservableBuffer<T,U extends java.util.Collection<? super T>> |
|
ObservableBuffer.BufferExactObserver<T,U extends java.util.Collection<? super T>> |
|
ObservableBuffer.BufferSkipObserver<T,U extends java.util.Collection<? super T>> |
|
ObservableBufferBoundary<T,U extends java.util.Collection<? super T>,Open,Close> |
|
ObservableBufferBoundary.BufferBoundaryObserver<T,C extends java.util.Collection<? super T>,Open,Close> |
|
ObservableBufferBoundary.BufferBoundaryObserver.BufferOpenObserver<Open> |
|
ObservableBufferBoundary.BufferCloseObserver<T,C extends java.util.Collection<? super T>> |
|
ObservableBufferExactBoundary<T,U extends java.util.Collection<? super T>,B> |
|
ObservableBufferExactBoundary.BufferBoundaryObserver<T,U extends java.util.Collection<? super T>,B> |
|
ObservableBufferExactBoundary.BufferExactBoundaryObserver<T,U extends java.util.Collection<? super T>,B> |
|
ObservableBufferTimed<T,U extends java.util.Collection<? super T>> |
|
ObservableBufferTimed.BufferExactBoundedObserver<T,U extends java.util.Collection<? super T>> |
|
ObservableBufferTimed.BufferExactUnboundedObserver<T,U extends java.util.Collection<? super T>> |
|
ObservableBufferTimed.BufferSkipBoundedObserver<T,U extends java.util.Collection<? super T>> |
|
ObservableCache<T> |
An observable which auto-connects to another observable, caches the elements
from that observable but allows terminating the connection and completing the cache.
|
ObservableCache.CacheDisposable<T> |
Hosts the downstream consumer and its current requested and replay states.
|
ObservableCache.Node<T> |
Represents a segment of the cached item list as
part of a linked-node-list structure.
|
ObservableCollect<T,U> |
|
ObservableCollect.CollectObserver<T,U> |
|
ObservableCollectSingle<T,U> |
|
ObservableCollectSingle.CollectObserver<T,U> |
|
ObservableCollectWithCollector<T,A,R> |
Collect items into a container defined by a Stream Collector callback set.
|
ObservableCollectWithCollector.CollectorObserver<T,A,R> |
|
ObservableCollectWithCollectorSingle<T,A,R> |
Collect items into a container defined by a Stream Collector callback set.
|
ObservableCollectWithCollectorSingle.CollectorSingleObserver<T,A,R> |
|
ObservableCombineLatest<T,R> |
|
ObservableCombineLatest.CombinerObserver<T,R> |
|
ObservableCombineLatest.LatestCoordinator<T,R> |
|
ObservableConcatMap<T,U> |
|
ObservableConcatMap.ConcatMapDelayErrorObserver<T,R> |
|
ObservableConcatMap.ConcatMapDelayErrorObserver.DelayErrorInnerObserver<R> |
|
ObservableConcatMap.SourceObserver<T,U> |
|
ObservableConcatMap.SourceObserver.InnerObserver<U> |
|
ObservableConcatMapCompletable<T> |
Maps the upstream items into CompletableSource s and subscribes to them one after the
other completes or terminates (in error-delaying mode).
|
ObservableConcatMapCompletable.ConcatMapCompletableObserver<T> |
|
ObservableConcatMapCompletable.ConcatMapCompletableObserver.ConcatMapInnerObserver |
|
ObservableConcatMapEager<T,R> |
|
ObservableConcatMapEager.ConcatMapEagerMainObserver<T,R> |
|
ObservableConcatMapMaybe<T,R> |
Maps each upstream item into a MaybeSource , subscribes to them one after the other terminates
and relays their success values, optionally delaying any errors till the main and inner sources
terminate.
|
ObservableConcatMapMaybe.ConcatMapMaybeMainObserver<T,R> |
|
ObservableConcatMapMaybe.ConcatMapMaybeMainObserver.ConcatMapMaybeObserver<R> |
|
ObservableConcatMapScheduler<T,U> |
|
ObservableConcatMapScheduler.ConcatMapDelayErrorObserver<T,R> |
|
ObservableConcatMapScheduler.ConcatMapDelayErrorObserver.DelayErrorInnerObserver<R> |
|
ObservableConcatMapScheduler.ConcatMapObserver<T,U> |
|
ObservableConcatMapScheduler.ConcatMapObserver.InnerObserver<U> |
|
ObservableConcatMapSingle<T,R> |
Maps each upstream item into a SingleSource , subscribes to them one after the other terminates
and relays their success values, optionally delaying any errors till the main and inner sources
terminate.
|
ObservableConcatMapSingle.ConcatMapSingleMainObserver<T,R> |
|
ObservableConcatMapSingle.ConcatMapSingleMainObserver.ConcatMapSingleObserver<R> |
|
ObservableConcatWithCompletable<T> |
Subscribe to a main Observable first, then when it completes normally, subscribe to a Single,
signal its success value followed by a completion or signal its error as is.
|
ObservableConcatWithCompletable.ConcatWithObserver<T> |
|
ObservableConcatWithMaybe<T> |
Subscribe to a main Observable first, then when it completes normally, subscribe to a Maybe,
signal its success value followed by a completion or signal its error or completion signal as is.
|
ObservableConcatWithMaybe.ConcatWithObserver<T> |
|
ObservableConcatWithSingle<T> |
Subscribe to a main Observable first, then when it completes normally, subscribe to a Single,
signal its success value followed by a completion or signal its error as is.
|
ObservableConcatWithSingle.ConcatWithObserver<T> |
|
ObservableConverter<T,R> |
|
ObservableCount<T> |
|
ObservableCount.CountObserver |
|
ObservableCountSingle<T> |
|
ObservableCountSingle.CountObserver |
|
ObservableCreate<T> |
|
ObservableCreate.CreateEmitter<T> |
|
ObservableCreate.SerializedEmitter<T> |
Serializes calls to onNext, onError and onComplete.
|
ObservableDebounce<T,U> |
|
ObservableDebounce.DebounceObserver<T,U> |
|
ObservableDebounce.DebounceObserver.DebounceInnerObserver<T,U> |
|
ObservableDebounceTimed<T> |
|
ObservableDebounceTimed.DebounceEmitter<T> |
|
ObservableDebounceTimed.DebounceTimedObserver<T> |
|
ObservableDefer<T> |
|
ObservableDelay<T> |
|
ObservableDelay.DelayObserver<T> |
|
ObservableDelaySubscriptionOther<T,U> |
Delays the subscription to the main source until the other
observable fires an event or completes.
|
ObservableDematerialize<T,R> |
|
ObservableDematerialize.DematerializeObserver<T,R> |
|
ObservableDetach<T> |
Breaks the links between the upstream and the downstream (the Disposable and
the Observer references) when the sequence terminates or gets disposed.
|
ObservableDetach.DetachObserver<T> |
|
ObservableDistinct<T,K> |
|
ObservableDistinct.DistinctObserver<T,K> |
|
ObservableDistinctUntilChanged<T,K> |
|
ObservableDistinctUntilChanged.DistinctUntilChangedObserver<T,K> |
|
ObservableDoAfterNext<T> |
Calls a consumer after pushing the current item to the downstream.
|
ObservableDoAfterNext.DoAfterObserver<T> |
|
ObservableDoFinally<T> |
Execute an action after an onError, onComplete or a dispose event.
|
ObservableDoFinally.DoFinallyObserver<T> |
|
ObservableDoOnEach<T> |
|
ObservableDoOnEach.DoOnEachObserver<T> |
|
ObservableDoOnLifecycle<T> |
|
ObservableElementAt<T> |
|
ObservableElementAt.ElementAtObserver<T> |
|
ObservableElementAtMaybe<T> |
|
ObservableElementAtMaybe.ElementAtObserver<T> |
|
ObservableElementAtSingle<T> |
|
ObservableElementAtSingle.ElementAtObserver<T> |
|
ObservableEmitter<T> |
Abstraction over an RxJava Observer that allows associating
a resource with it.
|
ObservableEmpty |
|
ObservableError<T> |
|
ObservableFilter<T> |
|
ObservableFilter.FilterObserver<T> |
|
ObservableFirstStageObserver<T> |
Signals the first element of the source via the underlying CompletableFuture,
signals the a default item if the upstream is empty or signals NoSuchElementException .
|
ObservableFlatMap<T,U> |
|
ObservableFlatMap.InnerObserver<T,U> |
|
ObservableFlatMap.MergeObserver<T,U> |
|
ObservableFlatMapCompletable<T> |
Maps a sequence of values into CompletableSources and awaits their termination.
|
ObservableFlatMapCompletable.FlatMapCompletableMainObserver<T> |
|
ObservableFlatMapCompletableCompletable<T> |
Maps a sequence of values into CompletableSources and awaits their termination.
|
ObservableFlatMapCompletableCompletable.FlatMapCompletableMainObserver<T> |
|
ObservableFlatMapMaybe<T,R> |
Maps upstream values into MaybeSources and merges their signals into one sequence.
|
ObservableFlatMapMaybe.FlatMapMaybeObserver<T,R> |
|
ObservableFlatMapSingle<T,R> |
Maps upstream values into SingleSources and merges their signals into one sequence.
|
ObservableFlatMapSingle.FlatMapSingleObserver<T,R> |
|
ObservableFlatMapStream<T,R> |
Maps the upstream values onto Stream s and emits their items in order to the downstream.
|
ObservableFlatMapStream.FlatMapStreamObserver<T,R> |
|
ObservableFlattenIterable<T,R> |
Maps a sequence into an Iterable and emits its values.
|
ObservableFlattenIterable.FlattenIterableObserver<T,R> |
|
ObservableFromAction<T> |
Executes an Action and signals its exception or completes normally.
|
ObservableFromArray<T> |
|
ObservableFromArray.FromArrayDisposable<T> |
|
ObservableFromCallable<T> |
Calls a Callable and emits its resulting single value or signals its exception.
|
ObservableFromCompletable<T> |
Wrap a Completable into an Observable.
|
ObservableFromCompletable.FromCompletableObserver<T> |
|
ObservableFromCompletionStage<T> |
Wrap a CompletionStage and signal its outcome.
|
ObservableFromCompletionStage.BiConsumerAtomicReference<T> |
|
ObservableFromCompletionStage.CompletionStageHandler<T> |
|
ObservableFromFuture<T> |
|
ObservableFromIterable<T> |
|
ObservableFromIterable.FromIterableDisposable<T> |
|
ObservableFromPublisher<T> |
|
ObservableFromPublisher.PublisherSubscriber<T> |
|
ObservableFromRunnable<T> |
Executes an Runnable and signals its exception or completes normally.
|
ObservableFromStream<T> |
Wraps a Stream and emits its values as an Observable sequence.
|
ObservableFromStream.StreamDisposable<T> |
|
ObservableFromSupplier<T> |
Calls a Supplier and emits its resulting single value or signals its exception.
|
ObservableFromUnsafeSource<T> |
|
ObservableGenerate<T,S> |
|
ObservableGenerate.GeneratorDisposable<T,S> |
|
ObservableGroupBy<T,K,V> |
|
ObservableGroupBy.GroupByObserver<T,K,V> |
|
ObservableGroupBy.GroupedUnicast<K,T> |
|
ObservableGroupBy.State<T,K> |
|
ObservableGroupJoin<TLeft,TRight,TLeftEnd,TRightEnd,R> |
|
ObservableGroupJoin.GroupJoinDisposable<TLeft,TRight,TLeftEnd,TRightEnd,R> |
|
ObservableGroupJoin.JoinSupport |
|
ObservableGroupJoin.LeftRightEndObserver |
|
ObservableGroupJoin.LeftRightObserver |
|
ObservableHide<T> |
Hides the identity of the wrapped ObservableSource and its Disposable.
|
ObservableHide.HideDisposable<T> |
|
ObservableIgnoreElements<T> |
|
ObservableIgnoreElements.IgnoreObservable<T> |
|
ObservableIgnoreElementsCompletable<T> |
|
ObservableIgnoreElementsCompletable.IgnoreObservable<T> |
|
ObservableInternalHelper |
Helper utility class to support Observable with inner classes.
|
ObservableInternalHelper.BufferedReplaySupplier<T> |
|
ObservableInternalHelper.BufferedTimedReplaySupplier<T> |
|
ObservableInternalHelper.FlatMapIntoIterable<T,U> |
|
ObservableInternalHelper.FlatMapWithCombinerInner<U,R,T> |
|
ObservableInternalHelper.FlatMapWithCombinerOuter<T,R,U> |
|
ObservableInternalHelper.ItemDelayFunction<T,U> |
|
ObservableInternalHelper.MapToInt |
|
ObservableInternalHelper.ObserverOnComplete<T> |
|
ObservableInternalHelper.ObserverOnError<T> |
|
ObservableInternalHelper.ObserverOnNext<T> |
|
ObservableInternalHelper.ReplaySupplier<T> |
|
ObservableInternalHelper.SimpleBiGenerator<T,S> |
|
ObservableInternalHelper.SimpleGenerator<T,S> |
|
ObservableInternalHelper.TimedReplayCallable<T> |
|
ObservableInterval |
|
ObservableInterval.IntervalObserver |
|
ObservableIntervalRange |
|
ObservableIntervalRange.IntervalRangeObserver |
|
ObservableJoin<TLeft,TRight,TLeftEnd,TRightEnd,R> |
|
ObservableJoin.JoinDisposable<TLeft,TRight,TLeftEnd,TRightEnd,R> |
|
ObservableJust<T> |
Represents a constant scalar value.
|
ObservableLastMaybe<T> |
Consumes the source ObservableSource and emits its last item, the defaultItem
if empty or a NoSuchElementException if even the defaultItem is null.
|
ObservableLastMaybe.LastObserver<T> |
|
ObservableLastSingle<T> |
Consumes the source ObservableSource and emits its last item, the defaultItem
if empty or a NoSuchElementException if even the defaultItem is null.
|
ObservableLastSingle.LastObserver<T> |
|
ObservableLastStageObserver<T> |
Signals the last element of the source via the underlying CompletableFuture,
signals the a default item if the upstream is empty or signals NoSuchElementException .
|
ObservableLift<R,T> |
Allows lifting operators into a chain of Observables.
|
ObservableMap<T,U> |
|
ObservableMap.MapObserver<T,U> |
|
ObservableMapNotification<T,R> |
|
ObservableMapNotification.MapNotificationObserver<T,R> |
|
ObservableMapOptional<T,R> |
Map the upstream values into an Optional and emit its value if any.
|
ObservableMapOptional.MapOptionalObserver<T,R> |
|
ObservableMaterialize<T> |
|
ObservableMaterialize.MaterializeObserver<T> |
|
ObservableMergeWithCompletable<T> |
Merges an Observable and a Completable by emitting the items of the Observable and waiting until
both the Observable and Completable complete normally.
|
ObservableMergeWithCompletable.MergeWithObserver<T> |
|
ObservableMergeWithCompletable.MergeWithObserver.OtherObserver |
|
ObservableMergeWithMaybe<T> |
Merges an Observable and a Maybe by emitting the items of the Observable and the success
value of the Maybe and waiting until both the Observable and Maybe terminate normally.
|
ObservableMergeWithMaybe.MergeWithObserver<T> |
|
ObservableMergeWithMaybe.MergeWithObserver.OtherObserver<T> |
|
ObservableMergeWithSingle<T> |
Merges an Observable and a Single by emitting the items of the Observable and the success
value of the Single and waiting until both the Observable and Single terminate normally.
|
ObservableMergeWithSingle.MergeWithObserver<T> |
|
ObservableMergeWithSingle.MergeWithObserver.OtherObserver<T> |
|
ObservableNever |
|
ObservableObserveOn<T> |
|
ObservableObserveOn.ObserveOnObserver<T> |
|
ObservableOnErrorComplete<T> |
Emits an onComplete if the source emits an onError and the predicate returns true for
that Throwable.
|
ObservableOnErrorComplete.OnErrorCompleteObserver<T> |
|
ObservableOnErrorNext<T> |
|
ObservableOnErrorNext.OnErrorNextObserver<T> |
|
ObservableOnErrorReturn<T> |
|
ObservableOnErrorReturn.OnErrorReturnObserver<T> |
|
ObservableOnSubscribe<T> |
A functional interface that has a subscribe() method that receives
an ObservableEmitter instance that allows pushing
events in a cancellation-safe manner.
|
ObservableOperator<Downstream,Upstream> |
Interface to map/wrap a downstream Observer to an upstream Observer .
|
ObservablePublish<T> |
Shares a single underlying connection to the upstream ObservableSource
and multicasts events to all subscribed observers until the upstream
completes or the connection is disposed.
|
ObservablePublish.InnerDisposable<T> |
Intercepts the dispose signal from the downstream and
removes itself from the connection's observers array
at most once.
|
ObservablePublish.PublishConnection<T> |
|
ObservablePublishSelector<T,R> |
Shares a source Observable for the duration of a selector function.
|
ObservablePublishSelector.SourceObserver<T> |
|
ObservablePublishSelector.TargetObserver<R> |
|
ObservableQueueDrain<T,U> |
|
ObservableRange |
Emits a range of integer values from start to end.
|
ObservableRange.RangeDisposable |
|
ObservableRangeLong |
|
ObservableRangeLong.RangeDisposable |
|
ObservableReduceMaybe<T> |
Reduce a sequence of values into a single value via an aggregator function and emit the final value or complete
if the source is empty.
|
ObservableReduceMaybe.ReduceObserver<T> |
|
ObservableReduceSeedSingle<T,R> |
Reduce a sequence of values, starting from a seed value and by using
an accumulator function and return the last accumulated value.
|
ObservableReduceSeedSingle.ReduceSeedObserver<T,R> |
|
ObservableReduceWithSingle<T,R> |
Reduce a sequence of values, starting from a generated seed value and by using
an accumulator function and return the last accumulated value.
|
ObservableRefCount<T> |
Returns an observable sequence that stays connected to the source as long as
there is at least one subscription to the observable sequence.
|
ObservableRefCount.RefConnection |
|
ObservableRefCount.RefCountObserver<T> |
|
ObservableRepeat<T> |
|
ObservableRepeat.RepeatObserver<T> |
|
ObservableRepeatUntil<T> |
|
ObservableRepeatUntil.RepeatUntilObserver<T> |
|
ObservableRepeatWhen<T> |
Repeatedly subscribe to a source if a handler ObservableSource signals an item.
|
ObservableRepeatWhen.RepeatWhenObserver<T> |
|
ObservableReplay<T> |
|
ObservableReplay.BoundedReplayBuffer<T> |
Base class for bounded buffering with options to specify an
enter and leave transforms and custom truncation behavior.
|
ObservableReplay.BufferSupplier<T> |
|
ObservableReplay.DisposeConsumer<R> |
|
ObservableReplay.InnerDisposable<T> |
A Disposable that manages the disposed state of a
child Observer in thread-safe manner.
|
ObservableReplay.MulticastReplay<R,U> |
|
ObservableReplay.Node |
Represents a node in a bounded replay buffer's linked list.
|
ObservableReplay.ReplayBuffer<T> |
The interface for interacting with various buffering logic.
|
ObservableReplay.ReplayBufferSupplier<T> |
|
ObservableReplay.ReplayObserver<T> |
|
ObservableReplay.ReplaySource<T> |
|
ObservableReplay.ScheduledReplaySupplier<T> |
|
ObservableReplay.SizeAndTimeBoundReplayBuffer<T> |
Size and time bound replay buffer.
|
ObservableReplay.SizeBoundReplayBuffer<T> |
A bounded replay buffer implementation with size limit only.
|
ObservableReplay.UnBoundedFactory |
|
ObservableReplay.UnboundedReplayBuffer<T> |
Holds an unbounded list of events.
|
ObservableRetryBiPredicate<T> |
|
ObservableRetryBiPredicate.RetryBiObserver<T> |
|
ObservableRetryPredicate<T> |
|
ObservableRetryPredicate.RepeatObserver<T> |
|
ObservableRetryWhen<T> |
Repeatedly subscribe to a source if a handler ObservableSource signals an item.
|
ObservableRetryWhen.RepeatWhenObserver<T> |
|
ObservableSampleTimed<T> |
|
ObservableSampleTimed.SampleTimedEmitLast<T> |
|
ObservableSampleTimed.SampleTimedNoLast<T> |
|
ObservableSampleTimed.SampleTimedObserver<T> |
|
ObservableSampleWithObservable<T> |
|
ObservableSampleWithObservable.SampleMainEmitLast<T> |
|
ObservableSampleWithObservable.SampleMainNoLast<T> |
|
ObservableSampleWithObservable.SampleMainObserver<T> |
|
ObservableSampleWithObservable.SamplerObserver<T> |
|
ObservableScalarXMap |
Utility classes to work with scalar-sourced XMap operators (where X == { flat, concat, switch }).
|
ObservableScalarXMap.ScalarDisposable<T> |
Represents a Disposable that signals one onNext followed by an onComplete.
|
ObservableScalarXMap.ScalarXMapObservable<T,R> |
Maps a scalar value to an ObservableSource and subscribes to it.
|
ObservableScan<T> |
|
ObservableScan.ScanObserver<T> |
|
ObservableScanSeed<T,R> |
|
ObservableScanSeed.ScanSeedObserver<T,R> |
|
ObservableSequenceEqual<T> |
|
ObservableSequenceEqual.EqualCoordinator<T> |
|
ObservableSequenceEqual.EqualObserver<T> |
|
ObservableSequenceEqualSingle<T> |
|
ObservableSequenceEqualSingle.EqualCoordinator<T> |
|
ObservableSequenceEqualSingle.EqualObserver<T> |
|
ObservableSerialized<T> |
|
ObservableSingleMaybe<T> |
|
ObservableSingleMaybe.SingleElementObserver<T> |
|
ObservableSingleSingle<T> |
|
ObservableSingleSingle.SingleElementObserver<T> |
|
ObservableSingleStageObserver<T> |
Signals the only element of the source via the underlying CompletableFuture,
signals the a default item if the upstream is empty or signals IllegalArgumentException
if the upstream has more than one item.
|
ObservableSkip<T> |
|
ObservableSkip.SkipObserver<T> |
|
ObservableSkipLast<T> |
|
ObservableSkipLast.SkipLastObserver<T> |
|
ObservableSkipLastTimed<T> |
|
ObservableSkipLastTimed.SkipLastTimedObserver<T> |
|
ObservableSkipUntil<T,U> |
|
ObservableSkipUntil.SkipUntilObserver<T> |
|
ObservableSkipWhile<T> |
|
ObservableSkipWhile.SkipWhileObserver<T> |
|
ObservableSource<T> |
Represents a basic, non-backpressured Observable source base interface,
consumable via an Observer .
|
ObservableStageObserver<T> |
Base class that extends CompletableFuture and provides basic infrastructure
to notify watchers upon upstream signals.
|
ObservableSubscribeOn<T> |
|
ObservableSubscribeOn.SubscribeOnObserver<T> |
|
ObservableSwitchIfEmpty<T> |
|
ObservableSwitchIfEmpty.SwitchIfEmptyObserver<T> |
|
ObservableSwitchMap<T,R> |
|
ObservableSwitchMap.SwitchMapInnerObserver<T,R> |
|
ObservableSwitchMap.SwitchMapObserver<T,R> |
|
ObservableSwitchMapCompletable<T> |
Maps the upstream values into CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running.
|
ObservableSwitchMapCompletable.SwitchMapCompletableObserver<T> |
|
ObservableSwitchMapCompletable.SwitchMapCompletableObserver.SwitchMapInnerObserver |
|
ObservableSwitchMapMaybe<T,R> |
Maps the upstream items into MaybeSource s and switches (subscribes) to the newer ones
while disposing the older ones and emits the latest success value if available, optionally delaying
errors from the main source or the inner sources.
|
ObservableSwitchMapMaybe.SwitchMapMaybeMainObserver<T,R> |
|
ObservableSwitchMapMaybe.SwitchMapMaybeMainObserver.SwitchMapMaybeObserver<R> |
|
ObservableSwitchMapSingle<T,R> |
Maps the upstream items into SingleSource s and switches (subscribes) to the newer ones
while disposing the older ones and emits the latest success value if available, optionally delaying
errors from the main source or the inner sources.
|
ObservableSwitchMapSingle.SwitchMapSingleMainObserver<T,R> |
|
ObservableSwitchMapSingle.SwitchMapSingleMainObserver.SwitchMapSingleObserver<R> |
|
ObservableTake<T> |
|
ObservableTake.TakeObserver<T> |
|
ObservableTakeLast<T> |
|
ObservableTakeLast.TakeLastObserver<T> |
|
ObservableTakeLastOne<T> |
|
ObservableTakeLastOne.TakeLastOneObserver<T> |
|
ObservableTakeLastTimed<T> |
|
ObservableTakeLastTimed.TakeLastTimedObserver<T> |
|
ObservableTakeUntil<T,U> |
|
ObservableTakeUntil.TakeUntilMainObserver<T,U> |
|
ObservableTakeUntilPredicate<T> |
|
ObservableTakeUntilPredicate.TakeUntilPredicateObserver<T> |
|
ObservableTakeWhile<T> |
|
ObservableTakeWhile.TakeWhileObserver<T> |
|
ObservableThrottleFirstTimed<T> |
|
ObservableThrottleFirstTimed.DebounceTimedObserver<T> |
|
ObservableThrottleLatest<T> |
Emits the next or latest item when the given time elapses.
|
ObservableThrottleLatest.ThrottleLatestObserver<T> |
|
ObservableTimeInterval<T> |
|
ObservableTimeInterval.TimeIntervalObserver<T> |
|
ObservableTimeout<T,U,V> |
|
ObservableTimeout.TimeoutConsumer |
|
ObservableTimeout.TimeoutFallbackObserver<T> |
|
ObservableTimeout.TimeoutObserver<T> |
|
ObservableTimeout.TimeoutSelectorSupport |
|
ObservableTimeoutTimed<T> |
|
ObservableTimeoutTimed.FallbackObserver<T> |
|
ObservableTimeoutTimed.TimeoutFallbackObserver<T> |
|
ObservableTimeoutTimed.TimeoutObserver<T> |
|
ObservableTimeoutTimed.TimeoutSupport |
|
ObservableTimeoutTimed.TimeoutTask |
|
ObservableTimer |
|
ObservableTimer.TimerObserver |
|
ObservableToList<T,U extends java.util.Collection<? super T>> |
|
ObservableToList.ToListObserver<T,U extends java.util.Collection<? super T>> |
|
ObservableToListSingle<T,U extends java.util.Collection<? super T>> |
|
ObservableToListSingle.ToListObserver<T,U extends java.util.Collection<? super T>> |
|
ObservableTransformer<Upstream,Downstream> |
|
ObservableUnsubscribeOn<T> |
|
ObservableUnsubscribeOn.UnsubscribeObserver<T> |
|
ObservableUsing<T,D> |
|
ObservableUsing.UsingObserver<T,D> |
|
ObservableWindow<T> |
|
ObservableWindow.WindowExactObserver<T> |
|
ObservableWindow.WindowSkipObserver<T> |
|
ObservableWindowBoundary<T,B> |
|
ObservableWindowBoundary.WindowBoundaryInnerObserver<T,B> |
|
ObservableWindowBoundary.WindowBoundaryMainObserver<T,B> |
|
ObservableWindowBoundarySelector<T,B,V> |
|
ObservableWindowBoundarySelector.WindowBoundaryMainObserver<T,B,V> |
|
ObservableWindowBoundarySelector.WindowBoundaryMainObserver.WindowEndObserverIntercept<T,V> |
|
ObservableWindowBoundarySelector.WindowBoundaryMainObserver.WindowStartItem<B> |
|
ObservableWindowBoundarySelector.WindowBoundaryMainObserver.WindowStartObserver<B> |
|
ObservableWindowSubscribeIntercept<T> |
Wrapper for a Subject that detects an incoming subscriber.
|
ObservableWindowTimed<T> |
|
ObservableWindowTimed.AbstractWindowObserver<T> |
|
ObservableWindowTimed.WindowExactBoundedObserver<T> |
|
ObservableWindowTimed.WindowExactBoundedObserver.WindowBoundaryRunnable |
|
ObservableWindowTimed.WindowExactUnboundedObserver<T> |
|
ObservableWindowTimed.WindowSkipObserver<T> |
|
ObservableWindowTimed.WindowSkipObserver.WindowBoundaryRunnable |
|
ObservableWithLatestFrom<T,U,R> |
|
ObservableWithLatestFrom.WithLatestFromObserver<T,U,R> |
|
ObservableWithLatestFromMany<T,R> |
Combines a main sequence of values with the latest from multiple other sequences via
a selector function.
|
ObservableWithLatestFromMany.WithLatestFromObserver<T,R> |
|
ObservableWithLatestFromMany.WithLatestInnerObserver |
|
ObservableZip<T,R> |
|
ObservableZip.ZipCoordinator<T,R> |
|
ObservableZip.ZipObserver<T,R> |
|
ObservableZipIterable<T,U,V> |
|
ObservableZipIterable.ZipIterableObserver<T,U,V> |
|
Observer<T> |
Provides a mechanism for receiving push-based notifications.
|
ObserverResourceWrapper<T> |
|
OnErrorNotImplementedException |
Represents an exception used to signal to the RxJavaPlugins.onError() that a
callback-based subscribe() method on a base reactive type didn't specify
an onError handler.
|
OpenHashSet<T> |
A simple open hash set with add, remove and clear capabilities only.
|
ParallelCollect<T,C> |
Reduce the sequence of values in each 'rail' to a single value.
|
ParallelCollect.ParallelCollectSubscriber<T,C> |
|
ParallelCollector<T,A,R> |
Reduces all 'rails' into a single via a Java 8 Collector callback set.
|
ParallelCollector.ParallelCollectorInnerSubscriber<T,A,R> |
|
ParallelCollector.ParallelCollectorSubscriber<T,A,R> |
|
ParallelCollector.SlotPair<T> |
|
ParallelConcatMap<T,R> |
Concatenates the generated Publishers on each rail.
|
ParallelDoOnNextTry<T> |
Calls a Consumer for each upstream value passing by
and handles any failure with a handler function.
|
ParallelDoOnNextTry.ParallelDoOnNextConditionalSubscriber<T> |
|
ParallelDoOnNextTry.ParallelDoOnNextSubscriber<T> |
|
ParallelFailureHandling |
Enumerations for handling failure within a parallel operator.
|
ParallelFilter<T> |
Filters each 'rail' of the source ParallelFlowable with a predicate function.
|
ParallelFilter.BaseFilterSubscriber<T> |
|
ParallelFilter.ParallelFilterConditionalSubscriber<T> |
|
ParallelFilter.ParallelFilterSubscriber<T> |
|
ParallelFilterTry<T> |
Filters each 'rail' of the source ParallelFlowable with a predicate function.
|
ParallelFilterTry.BaseFilterSubscriber<T> |
|
ParallelFilterTry.ParallelFilterConditionalSubscriber<T> |
|
ParallelFilterTry.ParallelFilterSubscriber<T> |
|
ParallelFlatMap<T,R> |
Flattens the generated Publishers on each rail.
|
ParallelFlatMapIterable<T,R> |
Flattens the generated Iterable s on each rail.
|
ParallelFlatMapStream<T,R> |
Flattens the generated Stream s on each rail.
|
ParallelFlowable<T> |
Abstract base class for parallel publishing of events signaled to an array of Subscriber s.
|
ParallelFlowableConverter<T,R> |
|
ParallelFromArray<T> |
Wraps multiple Publishers into a ParallelFlowable which runs them
in parallel.
|
ParallelFromPublisher<T> |
Dispatches the values from upstream in a round robin fashion to subscribers which are
ready to consume elements.
|
ParallelFromPublisher.ParallelDispatcher<T> |
|
ParallelJoin<T> |
Merges the individual 'rails' of the source ParallelFlowable, unordered,
into a single regular Publisher sequence (exposed as Flowable).
|
ParallelJoin.JoinInnerSubscriber<T> |
|
ParallelJoin.JoinSubscription<T> |
|
ParallelJoin.JoinSubscriptionBase<T> |
|
ParallelJoin.JoinSubscriptionDelayError<T> |
|
ParallelMap<T,R> |
Maps each 'rail' of the source ParallelFlowable with a mapper function.
|
ParallelMap.ParallelMapConditionalSubscriber<T,R> |
|
ParallelMap.ParallelMapSubscriber<T,R> |
|
ParallelMapOptional<T,R> |
Maps each 'rail' of the source ParallelFlowable with a mapper function.
|
ParallelMapOptional.ParallelMapConditionalSubscriber<T,R> |
|
ParallelMapOptional.ParallelMapSubscriber<T,R> |
|
ParallelMapTry<T,R> |
Maps each 'rail' of the source ParallelFlowable with a mapper function
and handle any failure based on a handler function.
|
ParallelMapTry.ParallelMapTryConditionalSubscriber<T,R> |
|
ParallelMapTry.ParallelMapTrySubscriber<T,R> |
|
ParallelMapTryOptional<T,R> |
Maps each 'rail' of the source ParallelFlowable with a mapper function
and handle any failure based on a handler function.
|
ParallelMapTryOptional.ParallelMapTryConditionalSubscriber<T,R> |
|
ParallelMapTryOptional.ParallelMapTrySubscriber<T,R> |
|
ParallelPeek<T> |
Execute a Consumer in each 'rail' for the current element passing through.
|
ParallelPeek.ParallelPeekSubscriber<T> |
|
ParallelReduce<T,R> |
Reduce the sequence of values in each 'rail' to a single value.
|
ParallelReduce.ParallelReduceSubscriber<T,R> |
|
ParallelReduceFull<T> |
Reduces all 'rails' into a single value which then gets reduced into a single
Publisher sequence.
|
ParallelReduceFull.ParallelReduceFullInnerSubscriber<T> |
|
ParallelReduceFull.ParallelReduceFullMainSubscriber<T> |
|
ParallelReduceFull.SlotPair<T> |
|
ParallelRunOn<T> |
Ensures each 'rail' from upstream runs on a Worker from a Scheduler.
|
ParallelRunOn.BaseRunOnSubscriber<T> |
|
ParallelRunOn.RunOnConditionalSubscriber<T> |
|
ParallelRunOn.RunOnSubscriber<T> |
|
ParallelSortedJoin<T> |
Given sorted rail sequences (according to the provided comparator) as List
emit the smallest item from these parallel Lists to the Subscriber.
|
ParallelSortedJoin.SortedJoinInnerSubscriber<T> |
|
ParallelSortedJoin.SortedJoinSubscription<T> |
|
ParallelTransformer<Upstream,Downstream> |
Interface to compose ParallelFlowable.
|
Pow2 |
|
Predicate<T> |
A functional interface (callback) that returns true or false for the given input value.
|
ProtocolViolationException |
Explicitly named exception to indicate a Reactive-Streams
protocol violation.
|
PublishProcessor<T> |
Processor that multicasts all subsequently observed items to its current Subscriber s.
|
PublishProcessor.PublishSubscription<T> |
Wraps the actual subscriber, tracks its requests and makes cancellation
to remove itself from the current subscribers array.
|
PublishSubject<T> |
A Subject that emits (multicasts) items to currently subscribed Observer s and terminal events to current
or late Observer s.
|
PublishSubject.PublishDisposable<T> |
Wraps the actual subscriber, tracks its requests and makes cancellation
to remove itself from the current subscribers array.
|
QueueDisposable<T> |
An interface extending SimpleQueue and Disposable and allows negotiating
the fusion mode between subsequent operators of the Observable base reactive type.
|
QueueDrain<T,U> |
|
QueueDrainHelper |
Utility class to help with the queue-drain serialization idiom.
|
QueueDrainObserver<T,U,V> |
Abstract base class for subscribers that hold another subscriber, a queue
and requires queue-drain behavior.
|
QueueDrainSubscriber<T,U,V> |
Abstract base class for subscribers that hold another subscriber, a queue
and requires queue-drain behavior.
|
QueueDrainSubscriberPad0 |
Pads the header away from other fields.
|
QueueDrainSubscriberPad0 |
Pads the header away from other fields.
|
QueueDrainSubscriberPad2 |
Pads away the wip from the other fields.
|
QueueDrainSubscriberPad2 |
Pads away the wip from the other fields.
|
QueueDrainSubscriberPad3 |
Contains the requested field.
|
QueueDrainSubscriberPad4 |
Pads away the requested from the other fields.
|
QueueDrainSubscriberWip |
The wip counter.
|
QueueDrainSubscriberWip |
The WIP counter.
|
QueueFuseable<T> |
Represents a SimpleQueue plus the means and constants for requesting a fusion mode.
|
QueueOverflowException |
Indicates an overflow happened because the upstream disregarded backpressure completely or
Subscriber.onNext(Object) was called concurrently from multiple threads
without synchronization.
|
QueueSubscription<T> |
An interface extending SimpleQueue and Subscription and allows negotiating
the fusion mode between subsequent operators of the Flowable base reactive type.
|
ReferenceDisposable<T> |
Base class for Disposable containers that manage some other type that
has to be run when the container is disposed.
|
ReplayProcessor<T> |
Replays events to Subscribers.
|
ReplayProcessor.Node<T> |
|
ReplayProcessor.ReplayBuffer<T> |
Abstraction over a buffer that receives events and replays them to
individual Subscribers.
|
ReplayProcessor.ReplaySubscription<T> |
|
ReplayProcessor.SizeAndTimeBoundReplayBuffer<T> |
|
ReplayProcessor.SizeBoundReplayBuffer<T> |
|
ReplayProcessor.TimedNode<T> |
|
ReplayProcessor.UnboundedReplayBuffer<T> |
|
ReplaySubject<T> |
Replays events (in a configurable bounded or unbounded manner) to current and late Observer s.
|
ReplaySubject.Node<T> |
|
ReplaySubject.ReplayBuffer<T> |
Abstraction over a buffer that receives events and replays them to
individual Observers.
|
ReplaySubject.ReplayDisposable<T> |
|
ReplaySubject.SizeAndTimeBoundReplayBuffer<T> |
|
ReplaySubject.SizeBoundReplayBuffer<T> |
|
ReplaySubject.TimedNode<T> |
|
ReplaySubject.UnboundedReplayBuffer<T> |
|
ResourceCompletableObserver |
An abstract CompletableObserver that allows asynchronous cancellation of its subscription and associated resources.
|
ResourceMaybeObserver<T> |
An abstract MaybeObserver that allows asynchronous cancellation of its subscription and associated resources.
|
ResourceObserver<T> |
An abstract Observer that allows asynchronous cancellation of its subscription and associated resources.
|
ResourceSingleObserver<T> |
An abstract SingleObserver that allows asynchronous cancellation of its subscription
and the associated resources.
|
ResourceSubscriber<T> |
An abstract Subscriber that allows asynchronous cancellation of its
subscription and associated resources.
|
ResumeSingleObserver<T> |
A SingleObserver implementation used for subscribing to the actual SingleSource
and replace the current Disposable in a parent AtomicReference.
|
RunnableDisposable |
A disposable container that manages a Runnable instance.
|
RxJavaPlugins |
Utility class to inject handlers to certain standard RxJava operations.
|
RxThreadFactory |
A ThreadFactory that counts how many threads have been created and given a prefix,
sets the created Thread's name to prefix-count .
|
RxThreadFactory.RxCustomThread |
|
SafeCompletableObserver |
Wraps another CompletableObserver and catches exceptions thrown by its
onSubscribe , onError or
onComplete methods despite the protocol forbids it.
|
SafeMaybeObserver<T> |
Wraps another MaybeObserver and catches exceptions thrown by its
onSubscribe , onSuccess , onError or
onComplete methods despite the protocol forbids it.
|
SafeObserver<T> |
Wraps another Observer and ensures all onXXX methods conform the protocol
(except the requirement for serialized access).
|
SafeSingleObserver<T> |
Wraps another SingleObserver and catches exceptions thrown by its
onSubscribe , onSuccess or onError methods despite
the protocol forbids it.
|
SafeSubscriber<T> |
Wraps another Subscriber and ensures all onXXX methods conform the protocol
(except the requirement for serialized access).
|
ScalarSubscription<T> |
A Subscription that holds a constant value and emits it only when requested.
|
ScalarSupplier<T> |
A marker interface indicating that a scalar, constant value
is held by the implementing reactive type which can be
safely extracted during assembly time can be used for
optimization.
|
ScalarXMapZHelper |
Utility class to extract a value from a scalar source reactive type,
map it to a 0-1 type then subscribe the output type's consumer to it,
saving on the overhead of the regular subscription channel.
|
ScheduledDirectPeriodicTask |
A Callable to be submitted to an ExecutorService that runs a Runnable
action periodically and manages completion/cancellation.
|
ScheduledDirectTask |
A Callable to be submitted to an ExecutorService that runs a Runnable
action and manages completion/cancellation.
|
ScheduledRunnable |
|
Scheduler |
A Scheduler is an object that specifies an API for scheduling
units of work provided in the form of Runnable s to be
executed without delay (effectively as soon as possible), after a specified time delay or periodically
and represents an abstraction over an asynchronous boundary that ensures
these units of work get executed by some underlying task-execution scheme
(such as custom Threads, event loop, Executor or Actor system)
with some uniform properties and guarantees regardless of the particular underlying
scheme.
|
Scheduler.DisposeTask |
|
Scheduler.PeriodicDirectTask |
|
Scheduler.Worker |
Represents an isolated, sequential worker of a parent Scheduler for executing Runnable tasks on
an underlying task-execution scheme (such as custom Threads, event loop, Executor or Actor system).
|
SchedulerMultiWorkerSupport |
Allows retrieving multiple workers from the implementing
Scheduler in a way that when asking for
at most the parallelism level of the Scheduler, those
Scheduler.Worker instances will be running
with different backing threads.
|
SchedulerMultiWorkerSupport.WorkerCallback |
|
SchedulerPoolFactory |
Manages the creating of ScheduledExecutorServices and sets up purging.
|
SchedulerPoolFactory.SystemPropertyAccessor |
|
SchedulerRunnableIntrospection |
|
Schedulers |
Static factory methods for returning standard Scheduler instances.
|
Schedulers.ComputationHolder |
|
Schedulers.ComputationTask |
|
Schedulers.IoHolder |
|
Schedulers.IOTask |
|
Schedulers.NewThreadHolder |
|
Schedulers.NewThreadTask |
|
Schedulers.SingleHolder |
|
Schedulers.SingleTask |
|
SchedulerSupport |
Indicates what kind of scheduler the class or method uses.
|
SchedulerWhen |
Allows the use of operators for controlling the timing around when actions
scheduled on workers are actually done.
|
SchedulerWhen.CreateWorkerFunction |
|
SchedulerWhen.DelayedAction |
|
SchedulerWhen.ImmediateAction |
|
SchedulerWhen.OnCompletedAction |
|
SchedulerWhen.QueueWorker |
|
SchedulerWhen.ScheduledAction |
|
SchedulerWhen.SubscribedDisposable |
|
SequentialDisposable |
A Disposable container that allows updating/replacing a Disposable
atomically and with respect of disposing the container itself.
|
SerialDisposable |
A Disposable container that allows atomically updating/replacing the contained
Disposable with another Disposable, disposing the old one when updating plus
handling the disposition when the container itself is disposed.
|
SerializedObserver<T> |
|
SerializedProcessor<T> |
Serializes calls to the Subscriber methods.
|
SerializedSubject<T> |
Serializes calls to the Observer methods.
|
SerializedSubscriber<T> |
Serializes access to the Subscriber.onNext(Object) , Subscriber.onError(Throwable) and
Subscriber.onComplete() methods of another Subscriber .
|
SimplePlainQueue<T> |
Override of the SimpleQueue interface with no throws Throwable on poll() .
|
SimpleQueue<T> |
A simplified interface for offering, polling and clearing a queue.
|
Single<T> |
The Single class implements the Reactive Pattern for a single value response.
|
SingleAmb<T> |
|
SingleAmb.AmbSingleObserver<T> |
|
SingleCache<T> |
|
SingleCache.CacheDisposable<T> |
|
SingleContains<T> |
|
SingleConverter<T,R> |
|
SingleCreate<T> |
|
SingleCreate.Emitter<T> |
|
SingleDefer<T> |
|
SingleDelay<T> |
|
SingleDelayWithCompletable<T> |
|
SingleDelayWithCompletable.OtherObserver<T> |
|
SingleDelayWithObservable<T,U> |
|
SingleDelayWithObservable.OtherSubscriber<T,U> |
|
SingleDelayWithPublisher<T,U> |
|
SingleDelayWithPublisher.OtherSubscriber<T,U> |
|
SingleDelayWithSingle<T,U> |
|
SingleDelayWithSingle.OtherObserver<T,U> |
|
SingleDematerialize<T,R> |
Maps the success value of the source to a Notification, then
maps it back to the corresponding signal type.
|
SingleDematerialize.DematerializeObserver<T,R> |
|
SingleDetach<T> |
Breaks the references between the upstream and downstream when the Maybe terminates.
|
SingleDetach.DetachSingleObserver<T> |
|
SingleDoAfterSuccess<T> |
Calls a consumer after pushing the current item to the downstream.
|
SingleDoAfterSuccess.DoAfterObserver<T> |
|
SingleDoAfterTerminate<T> |
Calls an action after pushing the current item or an error to the downstream.
|
SingleDoAfterTerminate.DoAfterTerminateObserver<T> |
|
SingleDoFinally<T> |
Execute an action after an onSuccess, onError or a dispose event.
|
SingleDoFinally.DoFinallyObserver<T> |
|
SingleDoOnDispose<T> |
|
SingleDoOnDispose.DoOnDisposeObserver<T> |
|
SingleDoOnError<T> |
|
SingleDoOnEvent<T> |
|
SingleDoOnLifecycle<T> |
Invokes callbacks upon onSubscribe from upstream and
dispose from downstream.
|
SingleDoOnLifecycle.SingleLifecycleObserver<T> |
|
SingleDoOnSubscribe<T> |
Calls a callback when the upstream calls onSubscribe with a disposable.
|
SingleDoOnSubscribe.DoOnSubscribeSingleObserver<T> |
|
SingleDoOnSuccess<T> |
|
SingleDoOnTerminate<T> |
|
SingleEmitter<T> |
Abstraction over an RxJava SingleObserver that allows associating
a resource with it.
|
SingleEquals<T> |
|
SingleEquals.InnerObserver<T> |
|
SingleError<T> |
|
SingleFlatMap<T,R> |
|
SingleFlatMap.SingleFlatMapCallback<T,R> |
|
SingleFlatMap.SingleFlatMapCallback.FlatMapSingleObserver<R> |
|
SingleFlatMapBiSelector<T,U,R> |
Maps a source item to another SingleSource then calls a BiFunction with the
original item and the secondary item to generate the final result.
|
SingleFlatMapBiSelector.FlatMapBiMainObserver<T,U,R> |
|
SingleFlatMapBiSelector.FlatMapBiMainObserver.InnerObserver<T,U,R> |
|
SingleFlatMapCompletable<T> |
Maps the success value of the source SingleSource into a Completable.
|
SingleFlatMapCompletable.FlatMapCompletableObserver<T> |
|
SingleFlatMapIterableFlowable<T,R> |
Maps a success value into an Iterable and streams it back as a Flowable.
|
SingleFlatMapIterableFlowable.FlatMapIterableObserver<T,R> |
|
SingleFlatMapIterableObservable<T,R> |
Maps a success value into an Iterable and streams it back as an Observable.
|
SingleFlatMapIterableObservable.FlatMapIterableObserver<T,R> |
|
SingleFlatMapMaybe<T,R> |
|
SingleFlatMapMaybe.FlatMapMaybeObserver<R> |
|
SingleFlatMapMaybe.FlatMapSingleObserver<T,R> |
|
SingleFlatMapNotification<T,R> |
Maps a value into a SingleSource and relays its signal.
|
SingleFlatMapNotification.FlatMapSingleObserver<T,R> |
|
SingleFlatMapObservable<T,R> |
Maps the success value of a Single onto an ObservableSource and
relays its signals to the downstream observer.
|
SingleFlatMapObservable.FlatMapObserver<T,R> |
|
SingleFlatMapPublisher<T,R> |
A Flowable that emits items based on applying a specified function to the item emitted by the
source Single, where that function returns a Publisher.
|
SingleFlatMapPublisher.SingleFlatMapPublisherObserver<S,T> |
|
SingleFlattenStreamAsFlowable<T,R> |
Map the success value into a Java Stream and emits its values.
|
SingleFlattenStreamAsObservable<T,R> |
Map the success value into a Java Stream and emits its values.
|
SingleFromCallable<T> |
|
SingleFromCompletionStage<T> |
Wrap a CompletionStage and signal its outcome.
|
SingleFromCompletionStage.CompletionStageHandler<T> |
|
SingleFromPublisher<T> |
|
SingleFromPublisher.ToSingleObserver<T> |
|
SingleFromSupplier<T> |
Calls a supplier and emits its value or exception to the incoming SingleObserver.
|
SingleFromUnsafeSource<T> |
|
SingleHide<T> |
|
SingleHide.HideSingleObserver<T> |
|
SingleInternalHelper |
Helper utility class to support Single with inner classes.
|
SingleInternalHelper.NoSuchElementSupplier |
|
SingleInternalHelper.ToFlowable |
|
SingleInternalHelper.ToFlowableIterable<T> |
|
SingleInternalHelper.ToFlowableIterator<T> |
|
SingleJust<T> |
|
SingleLift<T,R> |
|
SingleMap<T,R> |
|
SingleMap.MapSingleObserver<T,R> |
|
SingleMapOptional<T,R> |
Maps the success value to an Optional and emits its non-empty value or completes.
|
SingleMapOptional.MapOptionalSingleObserver<T,R> |
|
SingleMaterialize<T> |
Turn the signal types of a Single source into a single Notification of
equal kind.
|
SingleNever |
|
SingleObserveOn<T> |
|
SingleObserveOn.ObserveOnSingleObserver<T> |
|
SingleObserver<T> |
Provides a mechanism for receiving push-based notification of a single value or an error.
|
SingleOnErrorComplete<T> |
Emits an onComplete if the source emits an onError and the predicate returns true for
that Throwable.
|
SingleOnErrorReturn<T> |
|
SingleOnSubscribe<T> |
A functional interface that has a subscribe() method that receives
a SingleEmitter instance that allows pushing
an event in a cancellation-safe manner.
|
SingleOperator<Downstream,Upstream> |
Interface to map/wrap a downstream SingleObserver to an upstream SingleObserver .
|
SinglePostCompleteSubscriber<T,R> |
Relays signals from upstream according to downstream requests and allows
signalling a final value followed by onComplete in a backpressure-aware manner.
|
SingleResumeNext<T> |
|
SingleResumeNext.ResumeMainSingleObserver<T> |
|
SingleScheduler |
A scheduler with a shared, single threaded underlying ScheduledExecutorService.
|
SingleScheduler.ScheduledWorker |
|
SingleSource<T> |
|
SingleSubject<T> |
Represents a hot Single-like source and consumer of events similar to Subjects.
|
SingleSubject.SingleDisposable<T> |
|
SingleSubscribeOn<T> |
|
SingleSubscribeOn.SubscribeOnObserver<T> |
|
SingleTakeUntil<T,U> |
Signals the events of the source Single or signals a CancellationException if the
other Publisher signalled first.
|
SingleTakeUntil.TakeUntilMainObserver<T> |
|
SingleTakeUntil.TakeUntilOtherSubscriber |
|
SingleTimeInterval<T> |
Measures the time between subscription and the success item emission
from the upstream and emits this as a Timed success value.
|
SingleTimeInterval.TimeIntervalSingleObserver<T> |
|
SingleTimeout<T> |
|
SingleTimeout.TimeoutMainObserver<T> |
|
SingleTimeout.TimeoutMainObserver.TimeoutFallbackObserver<T> |
|
SingleTimer |
Signals a 0L after the specified delay.
|
SingleTimer.TimerDisposable |
|
SingleToFlowable<T> |
Wraps a Single and exposes it as a Flowable.
|
SingleToFlowable.SingleToFlowableObserver<T> |
|
SingleToObservable<T> |
Wraps a Single and exposes it as an Observable.
|
SingleToObservable.SingleToObservableObserver<T> |
|
SingleTransformer<Upstream,Downstream> |
|
SingleUnsubscribeOn<T> |
Makes sure a dispose() call from downstream happens on the specified scheduler.
|
SingleUnsubscribeOn.UnsubscribeOnSingleObserver<T> |
|
SingleUsing<T,U> |
|
SingleUsing.UsingSingleObserver<T,U> |
|
SingleZipArray<T,R> |
|
SingleZipArray.ZipCoordinator<T,R> |
|
SingleZipArray.ZipSingleObserver<T> |
|
SingleZipIterable<T,R> |
|
SorterFunction<T> |
|
SpscArrayQueue<E> |
A Single-Producer-Single-Consumer queue backed by a pre-allocated buffer.
|
SpscLinkedArrayQueue<T> |
A single-producer single-consumer array-backed queue which can allocate new arrays in case the consumer is slower
than the producer.
|
StrictSubscriber<T> |
Ensures that the event flow between the upstream and downstream follow
the Reactive-Streams 1.0 specification by honoring the 3 additional rules
(which are omitted in standard operators due to performance reasons).
|
Subject<T> |
Represents an Observer and an Observable at the same time, allowing
multicasting events from a single source to multiple child Observer s.
|
SubscriberResourceWrapper<T> |
|
SubscriptionArbiter |
Arbitrates requests and cancellation between Subscriptions.
|
SubscriptionDisposable |
A Disposable container that handles a Subscription .
|
SubscriptionHelper |
Utility methods to validate Subscriptions in the various onSubscribe calls.
|
Supplier<T> |
A functional interface (callback) that provides a single value or
throws an exception.
|
SuppressAnimalSniffer |
Suppress errors by the AnimalSniffer plugin.
|
TestObserver<T> |
|
TestObserver.EmptyObserver |
An observer that ignores all events and does not report errors.
|
TestScheduler |
A special, non thread-safe scheduler for testing operators that require
a scheduler without introducing real concurrency and allows manually advancing
a virtual time.
|
TestScheduler.TimedRunnable |
|
TestSubscriber<T> |
A Subscriber implementation that records events and allows making assertions about them.
|
TestSubscriber.EmptySubscriber |
A subscriber that ignores all events and does not report errors.
|
Timed<T> |
Holds onto a value along with time information.
|
TrampolineScheduler |
Schedules work on the current thread but does not execute immediately.
|
TrampolineScheduler.SleepingRunnable |
|
TrampolineScheduler.TimedRunnable |
|
TrampolineScheduler.TrampolineWorker |
|
UndeliverableException |
|
UnicastProcessor<T> |
A FlowableProcessor variant that queues up events until a single Subscriber subscribes to it, replays
those events to it until the Subscriber catches up and then switches to relaying events live to
this single Subscriber until this UnicastProcessor terminates or the Subscriber cancels
its subscription.
|
UnicastSubject<T> |
A Subject that queues up events until a single Observer subscribes to it, replays
those events to it until the Observer catches up and then switches to relaying events live to
this single Observer until this UnicastSubject terminates or the Observer disposes.
|
VolatileSizeArrayList<T> |
Tracks the current underlying array size in a volatile field.
|