Skip navigation links
RxJava 2.1.16.redhat-00001
A B C D E F G H I J K L M N O P Q R S T U V W Z 

A

accept(T1, T2) - Method in interface io.reactivex.functions.BiConsumer
Performs an operation on the given values.
accept(T) - Method in interface io.reactivex.functions.Consumer
Consume the given value.
accept(long) - Method in interface io.reactivex.functions.LongConsumer
Consume a primitive long input.
accept(Subscription) - Method in class io.reactivex.internal.functions.Functions.BoundedConsumer
 
accept(Throwable) - Method in class io.reactivex.internal.observers.CallbackCompletableObserver
 
accept(Observer<? super V>, U) - Method in class io.reactivex.internal.observers.QueueDrainObserver
 
accept(Subscription) - Method in enum io.reactivex.internal.operators.flowable.FlowableInternalHelper.RequestMax
 
accept(T) - Method in class io.reactivex.internal.operators.flowable.FlowableOnBackpressureDrop
 
accept(Subscriber<? super V>, U) - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
accept(Subscriber<? super U>) - Method in class io.reactivex.internal.util.AppendOnlyLinkedArrayList
Interprets the contents as NotificationLite objects and calls the appropriate Subscriber method.
accept(Observer<? super U>) - Method in class io.reactivex.internal.util.AppendOnlyLinkedArrayList
Interprets the contents as NotificationLite objects and calls the appropriate Observer method.
accept(Throwable) - Method in class io.reactivex.internal.util.BlockingIgnoringReceiver
 
accept(Disposable) - Method in class io.reactivex.internal.util.ConnectConsumer
 
accept(Object, Subscriber<? super T>) - Static method in enum io.reactivex.internal.util.NotificationLite
Calls the appropriate Subscriber method based on the type of the notification.
accept(Object, Observer<? super T>) - Static method in enum io.reactivex.internal.util.NotificationLite
Calls the appropriate Observer method based on the type of the notification.
accept(Observer<? super U>, T) - Method in interface io.reactivex.internal.util.ObservableQueueDrain
Accept the value and return true if forwarded.
accept(Subscriber<? super U>, T) - Method in interface io.reactivex.internal.util.QueueDrain
Accept the value and return true if forwarded.
acceptFull(Object, Subscriber<? super T>) - Static method in enum io.reactivex.internal.util.NotificationLite
Calls the appropriate Subscriber method based on the type of the notification.
acceptFull(Object, Observer<? super T>) - Static method in enum io.reactivex.internal.util.NotificationLite
Calls the appropriate Observer method based on the type of the notification.
Action - Interface in io.reactivex.functions
A functional interface similar to Runnable but allows throwing a checked exception.
actionConsumer(Action) - Static method in class io.reactivex.internal.functions.Functions
 
actual - Variable in class io.reactivex.internal.observers.BasicFuseableObserver
The downstream subscriber.
actual - Variable in class io.reactivex.internal.observers.DeferredScalarDisposable
The target of the events.
actual - Variable in class io.reactivex.internal.observers.QueueDrainObserver
 
actual - Variable in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
The downstream subscriber.
actual - Variable in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
The downstream subscriber.
actual - Variable in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
actual - Variable in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
The downstream consumer.
actual - Variable in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
The Subscriber to emit the value to.
add(Disposable) - Method in class io.reactivex.disposables.CompositeDisposable
Adds a disposable to this container or disposes it if the container has been disposed.
add(Disposable) - Method in interface io.reactivex.internal.disposables.DisposableContainer
Adds a disposable to this container or disposes it if the container has been disposed.
add(Disposable) - Method in class io.reactivex.internal.disposables.ListCompositeDisposable
 
add(T) - Method in class io.reactivex.internal.util.AppendOnlyLinkedArrayList
Append a non-null value to the list.
add(AtomicLong, long) - Static method in class io.reactivex.internal.util.BackpressureHelper
Atomically adds the positive value n to the requested value in the AtomicLong and caps the result at Long.MAX_VALUE and returns the previous value.
add(Object) - Method in class io.reactivex.internal.util.LinkedArrayList
Adds a new element to this list.
add(T) - Method in class io.reactivex.internal.util.OpenHashSet
 
add(T) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
add(int, T) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
add(Disposable) - Method in class io.reactivex.observers.ResourceCompletableObserver
Adds a resource to this ResourceObserver.
add(Disposable) - Method in class io.reactivex.observers.ResourceMaybeObserver
Adds a resource to this ResourceObserver.
add(Disposable) - Method in class io.reactivex.observers.ResourceObserver
Adds a resource to this ResourceObserver.
add(Disposable) - Method in class io.reactivex.observers.ResourceSingleObserver
Adds a resource to this ResourceObserver.
add(Disposable) - Method in class io.reactivex.subscribers.ResourceSubscriber
Adds a resource to this AsyncObserver.
addAll(Disposable...) - Method in class io.reactivex.disposables.CompositeDisposable
Atomically adds the given array of Disposables to the container or disposes them all if the container has been disposed.
addAll(Disposable...) - Method in class io.reactivex.internal.disposables.ListCompositeDisposable
 
addAll(Collection<? extends T>) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
addAll(int, Collection<? extends T>) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
addCancel(AtomicLong, long) - Static method in class io.reactivex.internal.util.BackpressureHelper
Atomically adds the positive value n to the requested value in the AtomicLong and caps the result at Long.MAX_VALUE and returns the previous value and considers Long.MIN_VALUE as a cancel indication (no addition then).
addCap(long, long) - Static method in class io.reactivex.internal.util.BackpressureHelper
Adds two long values and caps the sum at Long.MAX_VALUE.
addThrowable(Throwable) - Method in class io.reactivex.internal.util.AtomicThrowable
Atomically adds a Throwable to this container (combining with a previous Throwable is necessary).
addThrowable(AtomicReference<Throwable>, Throwable) - Static method in class io.reactivex.internal.util.ExceptionHelper
 
advanceTimeBy(long, TimeUnit) - Method in class io.reactivex.schedulers.TestScheduler
Moves the Scheduler's clock forward by a specified amount of time.
advanceTimeTo(long, TimeUnit) - Method in class io.reactivex.schedulers.TestScheduler
Moves the Scheduler's clock to a particular moment in time.
afterDownstream() - Method in class io.reactivex.internal.observers.BasicFuseableObserver
Override this to perform actions after the call to actual.onSubscribe(this) happened.
afterDownstream() - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
Override this to perform actions after the call to actual.onSubscribe(this) happened.
afterDownstream() - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
Override this to perform actions after the call to actual.onSubscribe(this) happened.
all(Predicate<? super T>) - Method in class io.reactivex.Flowable
Returns a Single that emits a Boolean that indicates whether all of the items emitted by the source Publisher satisfy a condition.
all(Predicate<? super T>) - Method in class io.reactivex.Observable
Returns a Single that emits a Boolean that indicates whether all of the items emitted by the source ObservableSource satisfy a condition.
alwaysFalse() - Static method in class io.reactivex.internal.functions.Functions
 
alwaysTrue() - Static method in class io.reactivex.internal.functions.Functions
 
amb(Iterable<? extends CompletableSource>) - Static method in class io.reactivex.Completable
Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.
amb(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Mirrors the one Publisher in an Iterable of several Publishers that first either emits an item or sends a termination notification.
amb(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Runs multiple MaybeSources and signals the events of the first one that signals (cancelling the rest).
amb(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Mirrors the one ObservableSource in an Iterable of several ObservableSources that first either emits an item or sends a termination notification.
amb(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Runs multiple SingleSources and signals the events of the first one that signals (cancelling the rest).
ambArray(CompletableSource...) - Static method in class io.reactivex.Completable
Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.
ambArray(Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Mirrors the one Publisher in an array of several Publishers that first either emits an item or sends a termination notification.
ambArray(MaybeSource<? extends T>...) - Static method in class io.reactivex.Maybe
Runs multiple MaybeSources and signals the events of the first one that signals (cancelling the rest).
ambArray(ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Mirrors the one ObservableSource in an array of several ObservableSources that first either emits an item or sends a termination notification.
ambArray(SingleSource<? extends T>...) - Static method in class io.reactivex.Single
Runs multiple SingleSources and signals the events of the first one that signals (cancelling the rest).
ambWith(CompletableSource) - Method in class io.reactivex.Completable
Returns a Completable that emits the a terminated event of either this Completable or the other Completable whichever fires first.
ambWith(Publisher<? extends T>) - Method in class io.reactivex.Flowable
Mirrors the Publisher (current or provided) that first either emits an item or sends a termination notification.
ambWith(MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Mirrors the MaybeSource (current or provided) that first signals an event.
ambWith(ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Mirrors the ObservableSource (current or provided) that first either emits an item or sends a termination notification.
ambWith(SingleSource<? extends T>) - Method in class io.reactivex.Single
Signals the event of this or the other SingleSource whichever signals first.
andThen(ObservableSource<T>) - Method in class io.reactivex.Completable
Returns an Observable which will subscribe to this Completable and once that is completed then will subscribe to the next ObservableSource.
andThen(Publisher<T>) - Method in class io.reactivex.Completable
Returns a Flowable which will subscribe to this Completable and once that is completed then will subscribe to the next Flowable.
andThen(SingleSource<T>) - Method in class io.reactivex.Completable
Returns a Single which will subscribe to this Completable and once that is completed then will subscribe to the next SingleSource.
andThen(MaybeSource<T>) - Method in class io.reactivex.Completable
Returns a Maybe which will subscribe to this Completable and once that is completed then will subscribe to the next MaybeSource.
andThen(CompletableSource) - Method in class io.reactivex.Completable
Returns a Completable that first runs this Completable and then the other completable.
any(Predicate<? super T>) - Method in class io.reactivex.Flowable
Returns a Single that emits true if any item emitted by the source Publisher satisfies a specified condition, otherwise false.
ANY - Static variable in interface io.reactivex.internal.fuseable.QueueFuseable
Request any of the QueueFuseable.SYNC or QueueFuseable.ASYNC modes.
any(Predicate<? super T>) - Method in class io.reactivex.Observable
Returns a Single that emits true if any item emitted by the source ObservableSource satisfies a specified condition, otherwise false.
AppendOnlyLinkedArrayList<T> - Class in io.reactivex.internal.util
A linked-array-list implementation that only supports appending and consumption.
AppendOnlyLinkedArrayList(int) - Constructor for class io.reactivex.internal.util.AppendOnlyLinkedArrayList
Constructs an empty list with a per-link capacity.
AppendOnlyLinkedArrayList.NonThrowingPredicate<T> - Interface in io.reactivex.internal.util
Predicate interface suppressing the exception.
apply(Completable) - Method in interface io.reactivex.CompletableConverter
Applies a function to the upstream Completable and returns a converted value of type R.
apply(CompletableObserver) - Method in interface io.reactivex.CompletableOperator
Applies a function to the child CompletableObserver and returns a new parent CompletableObserver.
apply(Completable) - Method in interface io.reactivex.CompletableTransformer
Applies a function to the upstream Completable and returns a CompletableSource.
apply(Flowable<T>) - Method in interface io.reactivex.FlowableConverter
Applies a function to the upstream Flowable and returns a converted value of type R.
apply(Subscriber<? super Downstream>) - Method in interface io.reactivex.FlowableOperator
Applies a function to the child Subscriber and returns a new parent Subscriber.
apply(Flowable<Upstream>) - Method in interface io.reactivex.FlowableTransformer
Applies a function to the upstream Flowable and returns a Publisher with optionally different element type.
apply(T1, T2) - Method in interface io.reactivex.functions.BiFunction
Calculate a value based on the input values.
apply(T) - Method in interface io.reactivex.functions.Function
Apply some calculation to the input value and return some other value.
apply(T1, T2, T3) - Method in interface io.reactivex.functions.Function3
Calculate a value based on the input values.
apply(T1, T2, T3, T4) - Method in interface io.reactivex.functions.Function4
Calculate a value based on the input values.
apply(T1, T2, T3, T4, T5) - Method in interface io.reactivex.functions.Function5
Calculate a value based on the input values.
apply(T1, T2, T3, T4, T5, T6) - Method in interface io.reactivex.functions.Function6
Calculate a value based on the input values.
apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface io.reactivex.functions.Function7
Calculate a value based on the input values.
apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface io.reactivex.functions.Function8
Calculate a value based on the input values.
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface io.reactivex.functions.Function9
Calculate a value based on the input values.
apply(int) - Method in interface io.reactivex.functions.IntFunction
Calculates a value based on a primitive integer input.
apply(MaybeSource<Object>) - Method in enum io.reactivex.internal.operators.maybe.MaybeToPublisher
 
apply(Object) - Method in enum io.reactivex.internal.util.ArrayListSupplier
 
apply(List, Object) - Method in enum io.reactivex.internal.util.ListAddBiConsumer
 
apply(List<T>, List<T>) - Method in class io.reactivex.internal.util.MergerBiFunction
 
apply(List<T>) - Method in class io.reactivex.internal.util.SorterFunction
 
apply(Maybe<T>) - Method in interface io.reactivex.MaybeConverter
Applies a function to the upstream Maybe and returns a converted value of type R.
apply(MaybeObserver<? super Downstream>) - Method in interface io.reactivex.MaybeOperator
Applies a function to the child MaybeObserver and returns a new parent MaybeObserver.
apply(Maybe<Upstream>) - Method in interface io.reactivex.MaybeTransformer
Applies a function to the upstream Maybe and returns a MaybeSource with optionally different element type.
apply(Observable<T>) - Method in interface io.reactivex.ObservableConverter
Applies a function to the upstream Observable and returns a converted value of type R.
apply(Observer<? super Downstream>) - Method in interface io.reactivex.ObservableOperator
Applies a function to the child Observer and returns a new parent Observer.
apply(Observable<Upstream>) - Method in interface io.reactivex.ObservableTransformer
Applies a function to the upstream Observable and returns an ObservableSource with optionally different element type.
apply(Long, Throwable) - Method in enum io.reactivex.parallel.ParallelFailureHandling
 
apply(ParallelFlowable<T>) - Method in interface io.reactivex.parallel.ParallelFlowableConverter
Applies a function to the upstream ParallelFlowable and returns a converted value of type R.
apply(ParallelFlowable<Upstream>) - Method in interface io.reactivex.parallel.ParallelTransformer
Applies a function to the upstream ParallelFlowable and returns a ParallelFlowable with optionally different element type.
apply(Single<T>) - Method in interface io.reactivex.SingleConverter
Applies a function to the upstream Single and returns a converted value of type R.
apply(SingleObserver<? super Downstream>) - Method in interface io.reactivex.SingleOperator
Applies a function to the child SingleObserver and returns a new parent SingleObserver.
apply(Single<Upstream>) - Method in interface io.reactivex.SingleTransformer
Applies a function to the upstream Single and returns a SingleSource with optionally different element type.
ArrayCompositeDisposable - Class in io.reactivex.internal.disposables
A composite disposable with a fixed number of slots.
ArrayCompositeDisposable(int) - Constructor for class io.reactivex.internal.disposables.ArrayCompositeDisposable
 
ArrayCompositeSubscription - Class in io.reactivex.internal.subscriptions
A composite disposable with a fixed number of slots.
ArrayCompositeSubscription(int) - Constructor for class io.reactivex.internal.subscriptions.ArrayCompositeSubscription
 
ArrayListSupplier - Enum in io.reactivex.internal.util
 
as(CompletableConverter<? extends R>) - Method in class io.reactivex.Completable
Calls the specified converter function during assembly time and returns its resulting value.
as(FlowableConverter<T, ? extends R>) - Method in class io.reactivex.Flowable
Calls the specified converter function during assembly time and returns its resulting value.
as(MaybeConverter<T, ? extends R>) - Method in class io.reactivex.Maybe
Calls the specified converter function during assembly time and returns its resulting value.
as(ObservableConverter<T, ? extends R>) - Method in class io.reactivex.Observable
Calls the specified converter function during assembly time and returns its resulting value.
as(ParallelFlowableConverter<T, R>) - Method in class io.reactivex.parallel.ParallelFlowable
Calls the specified converter function during assembly time and returns its resulting value.
as(SingleConverter<T, ? extends R>) - Method in class io.reactivex.Single
Calls the specified converter function during assembly time and returns its resulting value.
asCallable() - Static method in enum io.reactivex.internal.util.ArrayListSupplier
 
asCallable() - Static method in enum io.reactivex.internal.util.HashMapSupplier
 
asFunction() - Static method in enum io.reactivex.internal.util.ArrayListSupplier
 
asObserver() - Static method in enum io.reactivex.internal.util.EmptyComponent
 
assertComplete() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that this TestObserver/TestSubscriber received exactly one onComplete event.
assertEmpty() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber has received a Disposable but no other events.
assertError(Throwable) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that this TestObserver/TestSubscriber received exactly the specified onError event value.
assertError(Class<? extends Throwable>) - Method in class io.reactivex.observers.BaseTestConsumer
Asserts that this TestObserver/TestSubscriber received exactly one onError event which is an instance of the specified errorClass class.
assertError(Predicate<Throwable>) - Method in class io.reactivex.observers.BaseTestConsumer
Asserts that this TestObserver/TestSubscriber received exactly one onError event for which the provided predicate returns true.
assertErrorMessage(String) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that there is a single error and it has the given message.
assertFailure(Class<? extends Throwable>, T...) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the upstream signalled the specified values in order and then failed with a specific class or subclass of Throwable.
assertFailure(Predicate<Throwable>, T...) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the upstream signalled the specified values in order and then failed with a Throwable for which the provided predicate returns true.
assertFailureAndMessage(Class<? extends Throwable>, String, T...) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the upstream signalled the specified values in order, then failed with a specific class or subclass of Throwable and with the given exact error message.
assertNever(T) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that this TestObserver/TestSubscriber did not receive an onNext value which is equal to the given value with respect to null-safe Object.equals.
assertNever(Predicate<? super T>) - Method in class io.reactivex.observers.BaseTestConsumer
Asserts that this TestObserver/TestSubscriber did not receive any onNext value for which the provided predicate returns true.
assertNoErrors() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that this TestObserver/TestSubscriber has not received any onError event.
assertNotComplete() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that this TestObserver/TestSubscriber has not received any onComplete event.
assertNoTimeout() - Method in class io.reactivex.observers.BaseTestConsumer
Asserts that some awaitX method has not timed out.
assertNotSubscribed() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the onSubscribe method hasn't been called at all.
assertNotSubscribed() - Method in class io.reactivex.observers.TestObserver
Assert that the onSubscribe method hasn't been called at all.
assertNotSubscribed() - Method in class io.reactivex.subscribers.TestSubscriber
Assert that the onSubscribe method hasn't been called at all.
assertNotTerminated() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber has not terminated (i.e., the terminal latch is still non-zero).
assertNoValues() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that this TestObserver/TestSubscriber has not received any onNext events.
assertOf(Consumer<? super TestObserver<T>>) - Method in class io.reactivex.observers.TestObserver
Run a check consumer with this TestObserver instance.
assertOf(Consumer<? super TestSubscriber<T>>) - Method in class io.reactivex.subscribers.TestSubscriber
Run a check consumer with this TestSubscriber instance.
assertResult(T...) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the upstream signalled the specified values in order and completed normally.
assertSubscribed() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the onSubscribe method was called exactly once.
assertSubscribed() - Method in class io.reactivex.observers.TestObserver
Assert that the onSubscribe method was called exactly once.
assertSubscribed() - Method in class io.reactivex.subscribers.TestSubscriber
Assert that the onSubscribe method was called exactly once.
assertTerminated() - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber terminated (i.e., the terminal latch reached zero).
assertTimeout() - Method in class io.reactivex.observers.BaseTestConsumer
Asserts that some awaitX method has timed out.
assertValue(T) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that this TestObserver/TestSubscriber received exactly one onNext value which is equal to the given value with respect to Objects.equals.
assertValue(Predicate<T>) - Method in class io.reactivex.observers.BaseTestConsumer
Asserts that this TestObserver/TestSubscriber received exactly one onNext value for which the provided predicate returns true.
assertValueAt(int, T) - Method in class io.reactivex.observers.BaseTestConsumer
Asserts that this TestObserver/TestSubscriber received an onNext value at the given index which is equal to the given value with respect to null-safe Object.equals.
assertValueAt(int, Predicate<T>) - Method in class io.reactivex.observers.BaseTestConsumer
Asserts that this TestObserver/TestSubscriber received an onNext value at the given index for the provided predicate returns true.
assertValueCount(int) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that this TestObserver/TestSubscriber received the specified number onNext events.
assertValues(T...) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber received only the specified values in the specified order.
assertValueSequence(Iterable<? extends T>) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber received only the specified sequence of values in the same order.
assertValueSequenceOnly(Iterable<? extends T>) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber received only the specified values in the specified order without terminating.
assertValueSet(Collection<? extends T>) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber received only the specified values in any order.
assertValueSetOnly(Collection<? extends T>) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber received only the specified values in any order without terminating.
assertValuesOnly(T...) - Method in class io.reactivex.observers.BaseTestConsumer
Assert that the TestObserver/TestSubscriber received only the specified values in the specified order without terminating.
asSubscriber() - Static method in enum io.reactivex.internal.util.EmptyComponent
 
ASYNC - Static variable in interface io.reactivex.internal.fuseable.QueueFuseable
Request an asynchronous fusion mode and can be returned by QueueFuseable.requestFusion(int) for an accepted mode.
AsyncProcessor<T> - Class in io.reactivex.processors
Processor that emits the very last value followed by a completion event or the received error to Subscribers.
AsyncSubject<T> - Class in io.reactivex.subjects
A Subject that emits the very last value followed by a completion event or the received error to Observers.
AsyncSubscription - Class in io.reactivex.internal.subscriptions
A subscription implementation that arbitrates exactly one other Subscription and can hold a single disposable resource.
AsyncSubscription() - Constructor for class io.reactivex.internal.subscriptions.AsyncSubscription
 
AsyncSubscription(Disposable) - Constructor for class io.reactivex.internal.subscriptions.AsyncSubscription
 
AtomicThrowable - Class in io.reactivex.internal.util
Atomic container for Throwables including combining and having a terminal state via ExceptionHelper.
AtomicThrowable() - Constructor for class io.reactivex.internal.util.AtomicThrowable
 
autoConnect() - Method in class io.reactivex.flowables.ConnectableFlowable
Returns a Flowable that automatically connects (at most once) to this ConnectableFlowable when the first Subscriber subscribes.
autoConnect(int) - Method in class io.reactivex.flowables.ConnectableFlowable
Returns a Flowable that automatically connects (at most once) to this ConnectableFlowable when the specified number of Subscribers subscribe to it.
autoConnect(int, Consumer<? super Disposable>) - Method in class io.reactivex.flowables.ConnectableFlowable
Returns a Flowable that automatically connects (at most once) to this ConnectableFlowable when the specified number of Subscribers subscribe to it and calls the specified callback with the Subscription associated with the established connection.
autoConnect() - Method in class io.reactivex.observables.ConnectableObservable
Returns an Observable that automatically connects (at most once) to this ConnectableObservable when the first Observer subscribes.
autoConnect(int) - Method in class io.reactivex.observables.ConnectableObservable
Returns an Observable that automatically connects (at most once) to this ConnectableObservable when the specified number of Observers subscribe to it.
autoConnect(int, Consumer<? super Disposable>) - Method in class io.reactivex.observables.ConnectableObservable
Returns an Observable that automatically connects (at most once) to this ConnectableObservable when the specified number of Subscribers subscribe to it and calls the specified callback with the Subscription associated with the established connection.
await() - Method in class io.reactivex.observers.BaseTestConsumer
Awaits until this TestObserver/TestSubscriber receives an onError or onComplete events.
await(long, TimeUnit) - Method in class io.reactivex.observers.BaseTestConsumer
Awaits the specified amount of time or until this TestObserver/TestSubscriber receives an onError or onComplete events, whichever happens first.
awaitCount(int) - Method in class io.reactivex.observers.BaseTestConsumer
Await until the TestObserver/TestSubscriber receives the given number of items or terminates by sleeping 10 milliseconds at a time up to 5000 milliseconds of timeout.
awaitCount(int, Runnable) - Method in class io.reactivex.observers.BaseTestConsumer
Await until the TestObserver/TestSubscriber receives the given number of items or terminates by waiting according to the wait strategy and up to 5000 milliseconds of timeout.
awaitCount(int, Runnable, long) - Method in class io.reactivex.observers.BaseTestConsumer
Await until the TestObserver/TestSubscriber receives the given number of items or terminates.
awaitDone(long, TimeUnit) - Method in class io.reactivex.observers.BaseTestConsumer
Awaits until the internal latch is counted down.
awaitForComplete(CountDownLatch, Disposable) - Static method in class io.reactivex.internal.util.BlockingHelper
 
awaitTerminalEvent() - Method in class io.reactivex.observers.BaseTestConsumer
Waits until the any terminal event has been received by this TestObserver/TestSubscriber or returns false if the wait has been interrupted.
awaitTerminalEvent(long, TimeUnit) - Method in class io.reactivex.observers.BaseTestConsumer
Awaits the specified amount of time or until this TestObserver/TestSubscriber receives an onError or onComplete events, whichever happens first.

B

BackpressureHelper - Class in io.reactivex.internal.util
Utility class to help with backpressure-related operations such as request aggregation.
BackpressureKind - Enum in io.reactivex.annotations
Enumeration for various kinds of backpressure support.
BackpressureOverflowStrategy - Enum in io.reactivex
Options to deal with buffer overflow when using onBackpressureBuffer.
BackpressureStrategy - Enum in io.reactivex
Represents the options for applying backpressure to a source sequence.
BackpressureSupport - Annotation Type in io.reactivex.annotations
Indicates the backpressure support kind of the associated operator or class.
BaseTestConsumer<T,U extends BaseTestConsumer<T,U>> - Class in io.reactivex.observers
Base class with shared infrastructure to support TestSubscriber and TestObserver.
BaseTestConsumer() - Constructor for class io.reactivex.observers.BaseTestConsumer
 
BaseTestConsumer.TestWaitStrategy - Enum in io.reactivex.observers
Enumeration of default wait strategies when waiting for a specific number of items in BaseTestConsumer.awaitCount(int, Runnable).
BasicFuseableConditionalSubscriber<T,R> - Class in io.reactivex.internal.subscribers
Base class for a fuseable intermediate subscriber.
BasicFuseableConditionalSubscriber(ConditionalSubscriber<? super R>) - Constructor for class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
Construct a BasicFuseableSubscriber by wrapping the given subscriber.
BasicFuseableObserver<T,R> - Class in io.reactivex.internal.observers
Base class for a fuseable intermediate observer.
BasicFuseableObserver(Observer<? super R>) - Constructor for class io.reactivex.internal.observers.BasicFuseableObserver
Construct a BasicFuseableObserver by wrapping the given subscriber.
BasicFuseableSubscriber<T,R> - Class in io.reactivex.internal.subscribers
Base class for a fuseable intermediate subscriber.
BasicFuseableSubscriber(Subscriber<? super R>) - Constructor for class io.reactivex.internal.subscribers.BasicFuseableSubscriber
Construct a BasicFuseableSubscriber by wrapping the given subscriber.
BasicIntQueueDisposable<T> - Class in io.reactivex.internal.observers
An abstract QueueDisposable implementation, extending an AtomicInteger, that defaults all unnecessary Queue methods to throw UnsupportedOperationException.
BasicIntQueueDisposable() - Constructor for class io.reactivex.internal.observers.BasicIntQueueDisposable
 
BasicIntQueueSubscription<T> - Class in io.reactivex.internal.subscriptions
Base class extending AtomicInteger (wip or request accounting) and QueueSubscription (fusion).
BasicIntQueueSubscription() - Constructor for class io.reactivex.internal.subscriptions.BasicIntQueueSubscription
 
BasicQueueDisposable<T> - Class in io.reactivex.internal.observers
An abstract QueueDisposable implementation that defaults all unnecessary Queue methods to throw UnsupportedOperationException.
BasicQueueDisposable() - Constructor for class io.reactivex.internal.observers.BasicQueueDisposable
 
BasicQueueSubscription<T> - Class in io.reactivex.internal.subscriptions
Base class extending AtomicLong (wip or request accounting) and QueueSubscription (fusion).
BasicQueueSubscription() - Constructor for class io.reactivex.internal.subscriptions.BasicQueueSubscription
 
beforeDownstream() - Method in class io.reactivex.internal.observers.BasicFuseableObserver
Override this to perform actions before the call actual.onSubscribe(this) happens.
beforeDownstream() - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
Override this to perform actions before the call actual.onSubscribe(this) happens.
beforeDownstream() - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
Override this to perform actions before the call actual.onSubscribe(this) happens.
BehaviorProcessor<T> - Class in io.reactivex.processors
Processor that emits the most recent item it has observed and all subsequent observed items to each subscribed Subscriber.
BehaviorSubject<T> - Class in io.reactivex.subjects
Subject that emits the most recent item it has observed and all subsequent observed items to each subscribed Observer.
Beta - Annotation Type in io.reactivex.annotations
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> - Interface in io.reactivex.functions
A functional interface (callback) that accepts two values (of possibly different types).
BiConsumerSingleObserver<T> - Class in io.reactivex.internal.observers
 
BiConsumerSingleObserver(BiConsumer<? super T, ? super Throwable>) - Constructor for class io.reactivex.internal.observers.BiConsumerSingleObserver
 
BiFunction<T1,T2,R> - Interface in io.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
BiPredicate<T1,T2> - Interface in io.reactivex.functions
A functional interface (callback) that returns true or false for the given input values.
blockingAwait() - Method in class io.reactivex.Completable
Subscribes to and awaits the termination of this Completable instance in a blocking manner and rethrows any exception emitted.
blockingAwait(long, TimeUnit) - Method in class io.reactivex.Completable
Subscribes to and awaits the termination of this Completable instance in a blocking manner with a specific timeout and rethrows any exception emitted within the timeout window.
blockingAwait(long, TimeUnit) - Method in class io.reactivex.internal.observers.BlockingMultiObserver
Block until the observer terminates and return true; return false if the wait times out.
BlockingBaseObserver<T> - Class in io.reactivex.internal.observers
 
BlockingBaseObserver() - Constructor for class io.reactivex.internal.observers.BlockingBaseObserver
 
BlockingBaseSubscriber<T> - Class in io.reactivex.internal.subscribers
 
BlockingBaseSubscriber() - Constructor for class io.reactivex.internal.subscribers.BlockingBaseSubscriber
 
blockingFirst() - Method in class io.reactivex.Flowable
Returns the first item emitted by this Flowable, or throws NoSuchElementException if it emits no items.
blockingFirst(T) - Method in class io.reactivex.Flowable
Returns the first item emitted by this Flowable, or a default value if it emits no items.
blockingFirst() - Method in class io.reactivex.Observable
Returns the first item emitted by this Observable, or throws NoSuchElementException if it emits no items.
blockingFirst(T) - Method in class io.reactivex.Observable
Returns the first item emitted by this Observable, or a default value if it emits no items.
BlockingFirstObserver<T> - Class in io.reactivex.internal.observers
Blocks until the upstream signals its first value or completes.
BlockingFirstObserver() - Constructor for class io.reactivex.internal.observers.BlockingFirstObserver
 
BlockingFirstSubscriber<T> - Class in io.reactivex.internal.subscribers
Blocks until the upstream signals its first value or completes.
BlockingFirstSubscriber() - Constructor for class io.reactivex.internal.subscribers.BlockingFirstSubscriber
 
BlockingFlowableIterable<T> - Class in io.reactivex.internal.operators.flowable
 
BlockingFlowableIterable(Flowable<T>, int) - Constructor for class io.reactivex.internal.operators.flowable.BlockingFlowableIterable
 
BlockingFlowableLatest<T> - Class in io.reactivex.internal.operators.flowable
Wait for and iterate over the latest values of the source observable.
BlockingFlowableLatest(Publisher<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.BlockingFlowableLatest
 
BlockingFlowableMostRecent<T> - Class in io.reactivex.internal.operators.flowable
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(Flowable<T>, T) - Constructor for class io.reactivex.internal.operators.flowable.BlockingFlowableMostRecent
 
BlockingFlowableNext<T> - Class in io.reactivex.internal.operators.flowable
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
BlockingFlowableNext(Publisher<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.BlockingFlowableNext
 
blockingForEach(Consumer<? super T>) - Method in class io.reactivex.Flowable
Consumes the upstream Flowable in a blocking fashion and invokes the given Consumer with each upstream item on the current thread until the upstream terminates.
blockingForEach(Consumer<? super T>) - Method in class io.reactivex.Observable
Consumes the upstream Observable in a blocking fashion and invokes the given Consumer with each upstream item on the current thread until the upstream terminates.
blockingGet() - Method in class io.reactivex.Completable
Subscribes to this Completable instance and blocks until it terminates, then returns null or the emitted exception if any.
blockingGet(long, TimeUnit) - Method in class io.reactivex.Completable
Subscribes to this Completable instance and blocks until it terminates or the specified timeout elapses, then returns null for normal termination or the emitted exception if any.
blockingGet() - Method in class io.reactivex.internal.observers.BlockingBaseObserver
Block until the first value arrives and return it, otherwise return null for an empty source and rethrow any exception.
blockingGet() - Method in class io.reactivex.internal.observers.BlockingMultiObserver
Block until the latch is counted down then rethrow any exception received (wrapped if checked) or return the received value (null if none).
blockingGet(T) - Method in class io.reactivex.internal.observers.BlockingMultiObserver
Block until the latch is counted down then rethrow any exception received (wrapped if checked) or return the received value (the defaultValue if none).
blockingGet() - Method in class io.reactivex.internal.subscribers.BlockingBaseSubscriber
Block until the first value arrives and return it, otherwise return null for an empty source and rethrow any exception.
blockingGet() - Method in class io.reactivex.Maybe
Waits in a blocking fashion until the current Maybe signals a success value (which is returned), null if completed or an exception (which is propagated).
blockingGet(T) - Method in class io.reactivex.Maybe
Waits in a blocking fashion until the current Maybe signals a success value (which is returned), defaultValue if completed or an exception (which is propagated).
blockingGet() - Method in class io.reactivex.Single
Waits in a blocking fashion until the current Single signals a success value (which is returned) or an exception (which is propagated).
blockingGetError() - Method in class io.reactivex.internal.observers.BlockingMultiObserver
Block until the latch is counted down and return the error received or null if no error happened.
blockingGetError(long, TimeUnit) - Method in class io.reactivex.internal.observers.BlockingMultiObserver
Block until the latch is counted down and return the error received or when the wait is interrupted or times out, null otherwise.
BlockingHelper - Class in io.reactivex.internal.util
Utility methods for helping common blocking operations.
BlockingIgnoringReceiver - Class in io.reactivex.internal.util
Stores an incoming Throwable (if any) and counts itself down.
BlockingIgnoringReceiver() - Constructor for class io.reactivex.internal.util.BlockingIgnoringReceiver
 
blockingIterable() - Method in class io.reactivex.Flowable
Converts this Flowable into an Iterable.
blockingIterable(int) - Method in class io.reactivex.Flowable
Converts this Flowable into an Iterable.
blockingIterable() - Method in class io.reactivex.Observable
Converts this Observable into an Iterable.
blockingIterable(int) - Method in class io.reactivex.Observable
Converts this Observable into an Iterable.
blockingLast() - Method in class io.reactivex.Flowable
Returns the last item emitted by this Flowable, or throws NoSuchElementException if this Flowable emits no items.
blockingLast(T) - Method in class io.reactivex.Flowable
Returns the last item emitted by this Flowable, or a default value if it emits no items.
blockingLast() - Method in class io.reactivex.Observable
Returns the last item emitted by this Observable, or throws NoSuchElementException if this Observable emits no items.
blockingLast(T) - Method in class io.reactivex.Observable
Returns the last item emitted by this Observable, or a default value if it emits no items.
BlockingLastObserver<T> - Class in io.reactivex.internal.observers
Blocks until the upstream signals its last value or completes.
BlockingLastObserver() - Constructor for class io.reactivex.internal.observers.BlockingLastObserver
 
BlockingLastSubscriber<T> - Class in io.reactivex.internal.subscribers
Blocks until the upstream signals its last value or completes.
BlockingLastSubscriber() - Constructor for class io.reactivex.internal.subscribers.BlockingLastSubscriber
 
blockingLatest() - Method in class io.reactivex.Flowable
Returns an Iterable that returns the latest item emitted by this Flowable, waiting if necessary for one to become available.
blockingLatest() - Method in class io.reactivex.Observable
Returns an Iterable that returns the latest item emitted by this Observable, waiting if necessary for one to become available.
blockingMostRecent(T) - Method in class io.reactivex.Flowable
Returns an Iterable that always returns the item most recently emitted by this Flowable.
blockingMostRecent(T) - Method in class io.reactivex.Observable
Returns an Iterable that always returns the item most recently emitted by this Observable.
BlockingMultiObserver<T> - Class in io.reactivex.internal.observers
A combined Observer that awaits the success or error signal via a CountDownLatch.
BlockingMultiObserver() - Constructor for class io.reactivex.internal.observers.BlockingMultiObserver
 
blockingNext() - Method in class io.reactivex.Flowable
Returns an Iterable that blocks until this Flowable emits another item, then returns that item.
blockingNext() - Method in class io.reactivex.Observable
Returns an Iterable that blocks until this Observable emits another item, then returns that item.
BlockingObservableIterable<T> - Class in io.reactivex.internal.operators.observable
 
BlockingObservableIterable(ObservableSource<? extends T>, int) - Constructor for class io.reactivex.internal.operators.observable.BlockingObservableIterable
 
BlockingObservableLatest<T> - Class in io.reactivex.internal.operators.observable
Wait for and iterate over the latest values of the source observable.
BlockingObservableLatest(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.BlockingObservableLatest
 
BlockingObservableMostRecent<T> - Class in io.reactivex.internal.operators.observable
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(ObservableSource<T>, T) - Constructor for class io.reactivex.internal.operators.observable.BlockingObservableMostRecent
 
BlockingObservableNext<T> - Class in io.reactivex.internal.operators.observable
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
BlockingObservableNext(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.BlockingObservableNext
 
BlockingObserver<T> - Class in io.reactivex.internal.observers
 
BlockingObserver(Queue<Object>) - Constructor for class io.reactivex.internal.observers.BlockingObserver
 
blockingSingle() - Method in class io.reactivex.Flowable
If this Flowable completes after emitting a single item, return that item, otherwise throw a NoSuchElementException.
blockingSingle(T) - Method in class io.reactivex.Flowable
If this Flowable completes after emitting a single item, return that item; if it emits more than one item, throw an IllegalArgumentException; if it emits no items, return a default value.
blockingSingle() - Method in class io.reactivex.Observable
If this Observable completes after emitting a single item, return that item, otherwise throw a NoSuchElementException.
blockingSingle(T) - Method in class io.reactivex.Observable
If this Observable completes after emitting a single item, return that item; if it emits more than one item, throw an IllegalArgumentException; if it emits no items, return a default value.
blockingSubscribe() - Method in class io.reactivex.Flowable
Runs the source Flowable to a terminal event, ignoring any values and rethrowing any exception.
blockingSubscribe(Consumer<? super T>) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Consumer<? super T>, int) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, int) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action, int) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Subscriber<? super T>) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the Subscriber methods on the current thread.
blockingSubscribe() - Method in class io.reactivex.Observable
Runs the source observable to a terminal event, ignoring any values and rethrowing any exception.
blockingSubscribe(Consumer<? super T>) - Method in class io.reactivex.Observable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Observable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.Observable
Subscribes to the source and calls the given callbacks on the current thread.
blockingSubscribe(Observer<? super T>) - Method in class io.reactivex.Observable
Subscribes to the source and calls the Observer methods on the current thread.
BlockingSubscriber<T> - Class in io.reactivex.internal.subscribers
 
BlockingSubscriber(Queue<Object>) - Constructor for class io.reactivex.internal.subscribers.BlockingSubscriber
 
BooleanSubscription - Class in io.reactivex.internal.subscriptions
Subscription implementation that ignores request but remembers the cancellation which can be checked via isCancelled.
BooleanSubscription() - Constructor for class io.reactivex.internal.subscriptions.BooleanSubscription
 
BooleanSupplier - Interface in io.reactivex.functions
A functional interface (callback) that returns a boolean value.
BOUNDARY - Static variable in interface io.reactivex.internal.fuseable.QueueFuseable
Used in binary or combination with the other constants as an input to QueueFuseable.requestFusion(int) indicating that the SimpleQueue.poll() will be called behind an asynchronous boundary and thus may change the non-trivial computation locations attached to the SimpleQueue.poll() chain of fused operators.
boundedConsumer(int) - Static method in class io.reactivex.internal.functions.Functions
 
BoundedSubscriber<T> - Class in io.reactivex.internal.subscribers
 
BoundedSubscriber(Consumer<? super T>, Consumer<? super Throwable>, Action, Consumer<? super Subscription>, int) - Constructor for class io.reactivex.internal.subscribers.BoundedSubscriber
 
buffer(int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(int, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(int, int, Callable<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(int, Callable<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(long, long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(long, long, TimeUnit, Scheduler, Callable<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(long, TimeUnit, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(long, TimeUnit, Scheduler, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(long, TimeUnit, Scheduler, int, Callable<U>, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(Flowable<? extends TOpening>, Function<? super TOpening, ? extends Publisher<? extends TClosing>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(Flowable<? extends TOpening>, Function<? super TOpening, ? extends Publisher<? extends TClosing>>, Callable<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(Publisher<B>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits non-overlapping buffered items from the source Publisher each time the specified boundary Publisher emits an item.
buffer(Publisher<B>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits non-overlapping buffered items from the source Publisher each time the specified boundary Publisher emits an item.
buffer(Publisher<B>, Callable<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits non-overlapping buffered items from the source Publisher each time the specified boundary Publisher emits an item.
buffer(Callable<? extends Publisher<B>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(Callable<? extends Publisher<B>>, Callable<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits buffers of items it collects from the source Publisher.
buffer(int) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(int, int) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(int, int, Callable<U>) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(int, Callable<U>) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(long, long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(long, long, TimeUnit, Scheduler, Callable<U>) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(long, TimeUnit, int) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(long, TimeUnit, Scheduler, int) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(long, TimeUnit, Scheduler, int, Callable<U>, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(ObservableSource<? extends TOpening>, Function<? super TOpening, ? extends ObservableSource<? extends TClosing>>) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(ObservableSource<? extends TOpening>, Function<? super TOpening, ? extends ObservableSource<? extends TClosing>>, Callable<U>) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(ObservableSource<B>) - Method in class io.reactivex.Observable
Returns an Observable that emits non-overlapping buffered items from the source ObservableSource each time the specified boundary ObservableSource emits an item.
buffer(ObservableSource<B>, int) - Method in class io.reactivex.Observable
Returns an Observable that emits non-overlapping buffered items from the source ObservableSource each time the specified boundary ObservableSource emits an item.
buffer(ObservableSource<B>, Callable<U>) - Method in class io.reactivex.Observable
Returns an Observable that emits non-overlapping buffered items from the source ObservableSource each time the specified boundary ObservableSource emits an item.
buffer(Callable<? extends ObservableSource<B>>) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
buffer(Callable<? extends ObservableSource<B>>, Callable<U>) - Method in class io.reactivex.Observable
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
bufferSize() - Static method in class io.reactivex.Flowable
Returns the default internal buffer size used by most async operators.
bufferSize() - Static method in class io.reactivex.Observable
Returns the default 'island' size or capacity-increment hint for unbounded buffers.

C

cache() - Method in class io.reactivex.Completable
Subscribes to this Completable only once, when the first CompletableObserver subscribes to the result Completable, caches its terminal event and relays/replays it to observers.
cache() - Method in class io.reactivex.Flowable
Returns a Flowable that subscribes to this Publisher lazily, caches all of its events and replays them, in the same order as received, to all the downstream subscribers.
cache() - Method in class io.reactivex.Maybe
Returns a Maybe that subscribes to this Maybe lazily, caches its event and replays it, to all the downstream subscribers.
cache() - Method in class io.reactivex.Observable
Returns an Observable that subscribes to this ObservableSource lazily, caches all of its events and replays them, in the same order as received, to all the downstream subscribers.
cache() - Method in class io.reactivex.Single
Stores the success value or exception from the current Single and replays it to late SingleObservers.
cacheWithInitialCapacity(int) - Method in class io.reactivex.Flowable
Returns a Flowable that subscribes to this Publisher lazily, caches all of its events and replays them, in the same order as received, to all the downstream subscribers.
cacheWithInitialCapacity(int) - Method in class io.reactivex.Observable
Returns an Observable that subscribes to this ObservableSource lazily, caches all of its events and replays them, in the same order as received, to all the downstream subscribers.
call() - Method in interface io.reactivex.internal.fuseable.ScalarCallable
 
call() - Method in class io.reactivex.internal.operators.flowable.FlowableEmpty
 
call() - Method in class io.reactivex.internal.operators.flowable.FlowableFromCallable
 
call() - Method in class io.reactivex.internal.operators.flowable.FlowableJust
 
call() - Method in class io.reactivex.internal.operators.maybe.MaybeEmpty
 
call() - Method in class io.reactivex.internal.operators.maybe.MaybeFromAction
 
call() - Method in class io.reactivex.internal.operators.maybe.MaybeFromCallable
 
call() - Method in class io.reactivex.internal.operators.maybe.MaybeFromRunnable
 
call() - Method in class io.reactivex.internal.operators.maybe.MaybeJust
 
call() - Method in class io.reactivex.internal.operators.observable.ObservableEmpty
 
call() - Method in class io.reactivex.internal.operators.observable.ObservableFromCallable
 
call() - Method in class io.reactivex.internal.operators.observable.ObservableJust
 
call() - Method in class io.reactivex.internal.schedulers.ScheduledDirectTask
 
call() - Method in class io.reactivex.internal.schedulers.ScheduledRunnable
 
call() - Method in enum io.reactivex.internal.util.ArrayListSupplier
 
call() - Method in enum io.reactivex.internal.util.HashMapSupplier
 
CallbackCompletableObserver - Class in io.reactivex.internal.observers
 
CallbackCompletableObserver(Action) - Constructor for class io.reactivex.internal.observers.CallbackCompletableObserver
 
CallbackCompletableObserver(Consumer<? super Throwable>, Action) - Constructor for class io.reactivex.internal.observers.CallbackCompletableObserver
 
cancel() - Method in interface io.reactivex.functions.Cancellable
Cancel the action or free a resource.
cancel(boolean) - Method in class io.reactivex.internal.observers.FutureObserver
 
cancel(boolean) - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
cancel() - Method in class io.reactivex.internal.observers.SubscriberCompletableObserver
 
cancel() - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
cancel(K) - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
cancel(K) - Method in class io.reactivex.internal.operators.observable.ObservableGroupBy.GroupByObserver
 
cancel() - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.BlockingSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.DeferredScalarSubscriber
 
cancel(boolean) - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.StrictSubscriber
 
cancel() - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
cancel() - Method in class io.reactivex.internal.subscriptions.AsyncSubscription
 
cancel() - Method in class io.reactivex.internal.subscriptions.BooleanSubscription
 
cancel() - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
 
cancel() - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
cancel() - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
 
cancel() - Method in class io.reactivex.internal.subscriptions.SubscriptionArbiter
 
cancel() - Method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
 
cancel(AtomicReference<Subscription>) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Atomically swaps in the common cancelled subscription instance and cancels the previous subscription if any.
cancel() - Method in enum io.reactivex.internal.util.EmptyComponent
 
cancel() - Method in class io.reactivex.observers.DefaultObserver
Cancels the upstream's disposable.
cancel() - Method in class io.reactivex.observers.TestObserver
Cancels the TestObserver (before or after the subscription happened).
cancel() - Method in class io.reactivex.subscribers.DefaultSubscriber
Cancels the upstream's Subscription.
cancel() - Method in class io.reactivex.subscribers.DisposableSubscriber
Cancels the Subscription set via onSubscribe or makes sure a Subscription set asynchronously (later) is cancelled immediately.
cancel() - Method in class io.reactivex.subscribers.SafeSubscriber
 
cancel() - Method in class io.reactivex.subscribers.SerializedSubscriber
 
cancel() - Method in class io.reactivex.subscribers.TestSubscriber
 
Cancellable - Interface in io.reactivex.functions
A functional interface that has a single cancel method that can throw.
CancellableDisposable - Class in io.reactivex.internal.disposables
A disposable container that wraps a Cancellable instance.
CancellableDisposable(Cancellable) - Constructor for class io.reactivex.internal.disposables.CancellableDisposable
 
cancelled - Variable in class io.reactivex.internal.observers.QueueDrainObserver
 
cancelled() - Method in class io.reactivex.internal.observers.QueueDrainObserver
 
cancelled - Variable in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
cancelled() - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
cancelled() - Method in interface io.reactivex.internal.util.ObservableQueueDrain
 
cancelled() - Method in interface io.reactivex.internal.util.QueueDrain
 
cast(Class<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by the source Publisher, converted to the specified type.
cast(Class<? extends U>) - Method in class io.reactivex.Maybe
Casts the success value of the current Maybe into the target type or signals a ClassCastException if not compatible.
cast(Class<U>) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by the source ObservableSource, converted to the specified type.
cast(Class<? extends U>) - Method in class io.reactivex.Single
Casts the success value of the current Single into the target type or signals a ClassCastException if not compatible.
castFunction(Class<U>) - Static method in class io.reactivex.internal.functions.Functions
Returns a function that cast the incoming values via a Class object.
CheckReturnValue - Annotation Type in io.reactivex.annotations
Marks methods whose return values should be checked.
checkSubscriptionOnce - Variable in class io.reactivex.observers.BaseTestConsumer
 
checkTerminated(boolean, boolean, Subscriber<?>, boolean, SimpleQueue<?>, QueueDrain<T, U>) - Static method in class io.reactivex.internal.util.QueueDrainHelper
 
checkTerminated(boolean, boolean, Observer<?>, boolean, SimpleQueue<?>, Disposable, ObservableQueueDrain<T, U>) - Static method in class io.reactivex.internal.util.QueueDrainHelper
 
cleanupBuffer() - Method in class io.reactivex.processors.ReplayProcessor
Makes sure the item cached by the head node in a bounded ReplayProcessor is released (as it is never part of a replay).
cleanupBuffer() - Method in class io.reactivex.subjects.ReplaySubject
Makes sure the item cached by the head node in a bounded ReplaySubject is released (as it is never part of a replay).
clear() - Method in class io.reactivex.disposables.CompositeDisposable
Atomically clears the container, then disposes all the previously contained Disposables.
clear() - Method in enum io.reactivex.internal.disposables.EmptyDisposable
 
clear() - Method in class io.reactivex.internal.disposables.ListCompositeDisposable
 
clear() - Method in interface io.reactivex.internal.fuseable.SimpleQueue
Removes all enqueued items from this queue.
clear() - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
clear() - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
 
clear() - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
clear() - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
clear() - Method in class io.reactivex.internal.queue.MpscLinkedQueue
 
clear() - Method in class io.reactivex.internal.queue.SpscArrayQueue
 
clear() - Method in class io.reactivex.internal.queue.SpscLinkedArrayQueue
 
clear() - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
clear() - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
clear() - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
 
clear() - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
clear() - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
 
clear() - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
clearTimeout() - Method in class io.reactivex.observers.BaseTestConsumer
Clears the timeout flag set by the await methods when they timed out.
clockDriftTolerance() - Static method in class io.reactivex.Scheduler
Returns the clock drift tolerance in nanoseconds.
collect(Callable<? extends U>, BiConsumer<? super U, ? super T>) - Method in class io.reactivex.Flowable
Collects items emitted by the finite source Publisher into a single mutable data structure and returns a Single that emits this structure.
collect(Callable<? extends U>, BiConsumer<? super U, ? super T>) - Method in class io.reactivex.Observable
Collects items emitted by the finite source ObservableSource into a single mutable data structure and returns a Single that emits this structure.
collect(Callable<? extends C>, BiConsumer<? super C, ? super T>) - Method in class io.reactivex.parallel.ParallelFlowable
Collect the elements in each rail into a collection supplied via a collectionSupplier and collected into with a collector action, emitting the collection at the end.
collectInto(U, BiConsumer<? super U, ? super T>) - Method in class io.reactivex.Flowable
Collects items emitted by the finite source Publisher into a single mutable data structure and returns a Single that emits this structure.
collectInto(U, BiConsumer<? super U, ? super T>) - Method in class io.reactivex.Observable
Collects items emitted by the finite source ObservableSource into a single mutable data structure and returns a Single that emits this structure.
combineLatest(Publisher<? extends T>[], Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Function<? super Object[], ? extends R>, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T>[], Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.Flowable
Combines two source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from either of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class io.reactivex.Flowable
Combines three source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class io.reactivex.Flowable
Combines four source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class io.reactivex.Flowable
Combines five source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class io.reactivex.Flowable
Combines six source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class io.reactivex.Flowable
Combines seven source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class io.reactivex.Flowable
Combines eight source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Publisher<? extends T9>, Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class io.reactivex.Flowable
Combines nine source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatest(Function<? super Object[], ? extends R>, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T>[], Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T>[], Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.Observable
Combines two source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from either of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class io.reactivex.Observable
Combines three source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class io.reactivex.Observable
Combines four source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class io.reactivex.Observable
Combines five source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class io.reactivex.Observable
Combines six source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class io.reactivex.Observable
Combines seven source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, ObservableSource<? extends T8>, Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class io.reactivex.Observable
Combines eight source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, ObservableSource<? extends T8>, ObservableSource<? extends T9>, Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class io.reactivex.Observable
Combines nine source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatestDelayError(Publisher<? extends T>[], Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function.
combineLatestDelayError(Function<? super Object[], ? extends R>, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function and delays any error from the sources until all source Publishers terminate.
combineLatestDelayError(Function<? super Object[], ? extends R>, int, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publisher, where this aggregation is defined by a specified function and delays any error from the sources until all source Publishers terminate.
combineLatestDelayError(Publisher<? extends T>[], Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function and delays any error from the sources until all source Publishers terminate.
combineLatestDelayError(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function and delays any error from the sources until all source Publishers terminate.
combineLatestDelayError(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.Flowable
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of the source Publishers each time an item is received from any of the source Publishers, where this aggregation is defined by a specified function and delays any error from the sources until all source Publishers terminate.
combineLatestDelayError(ObservableSource<? extends T>[], Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function.
combineLatestDelayError(Function<? super Object[], ? extends R>, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function and delays any error from the sources until all source ObservableSources terminate.
combineLatestDelayError(ObservableSource<? extends T>[], Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function and delays any error from the sources until all source ObservableSources terminate.
combineLatestDelayError(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function and delays any error from the sources until all source ObservableSources terminate.
combineLatestDelayError(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.Observable
Combines a collection of source ObservableSources by emitting an item that aggregates the latest values of each of the source ObservableSources each time an item is received from any of the source ObservableSources, where this aggregation is defined by a specified function and delays any error from the sources until all source ObservableSources terminate.
compare(int, int) - Static method in class io.reactivex.internal.functions.ObjectHelper
Compares two integer values similar to Integer.compare.
compare(long, long) - Static method in class io.reactivex.internal.functions.ObjectHelper
Compares two long values similar to Long.compare.
Completable - Class in io.reactivex
Represents a deferred computation without any value but only indication for completion or exception.
Completable() - Constructor for class io.reactivex.Completable
 
CompletableAmb - Class in io.reactivex.internal.operators.completable
 
CompletableAmb(CompletableSource[], Iterable<? extends CompletableSource>) - Constructor for class io.reactivex.internal.operators.completable.CompletableAmb
 
CompletableAndThenObservable<R> - Class in io.reactivex.internal.operators.mixed
After Completable completes, it relays the signals of the ObservableSource to the downstream observer.
CompletableAndThenObservable(CompletableSource, ObservableSource<? extends R>) - Constructor for class io.reactivex.internal.operators.mixed.CompletableAndThenObservable
 
CompletableAndThenPublisher<R> - Class in io.reactivex.internal.operators.mixed
After Completable completes, it relays the signals of the Publisher to the downstream subscriber.
CompletableAndThenPublisher(CompletableSource, Publisher<? extends R>) - Constructor for class io.reactivex.internal.operators.mixed.CompletableAndThenPublisher
 
CompletableCache - Class in io.reactivex.internal.operators.completable
Consume the upstream source exactly once and cache its terminal event.
CompletableCache(CompletableSource) - Constructor for class io.reactivex.internal.operators.completable.CompletableCache
 
CompletableConcat - Class in io.reactivex.internal.operators.completable
 
CompletableConcat(Publisher<? extends CompletableSource>, int) - Constructor for class io.reactivex.internal.operators.completable.CompletableConcat
 
CompletableConcatArray - Class in io.reactivex.internal.operators.completable
 
CompletableConcatArray(CompletableSource[]) - Constructor for class io.reactivex.internal.operators.completable.CompletableConcatArray
 
CompletableConcatIterable - Class in io.reactivex.internal.operators.completable
 
CompletableConcatIterable(Iterable<? extends CompletableSource>) - Constructor for class io.reactivex.internal.operators.completable.CompletableConcatIterable
 
CompletableConverter<R> - Interface in io.reactivex
Convenience interface and callback used by the Completable.as(io.reactivex.CompletableConverter<? extends R>) operator to turn a Completable into another value fluently.
CompletableCreate - Class in io.reactivex.internal.operators.completable
 
CompletableCreate(CompletableOnSubscribe) - Constructor for class io.reactivex.internal.operators.completable.CompletableCreate
 
CompletableDefer - Class in io.reactivex.internal.operators.completable
 
CompletableDefer(Callable<? extends CompletableSource>) - Constructor for class io.reactivex.internal.operators.completable.CompletableDefer
 
CompletableDelay - Class in io.reactivex.internal.operators.completable
 
CompletableDelay(CompletableSource, long, TimeUnit, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.completable.CompletableDelay
 
CompletableDetach - Class in io.reactivex.internal.operators.completable
Breaks the references between the upstream and downstream when the Completable terminates.
CompletableDetach(CompletableSource) - Constructor for class io.reactivex.internal.operators.completable.CompletableDetach
 
CompletableDisposeOn - Class in io.reactivex.internal.operators.completable
 
CompletableDisposeOn(CompletableSource, Scheduler) - Constructor for class io.reactivex.internal.operators.completable.CompletableDisposeOn
 
CompletableDoFinally - Class in io.reactivex.internal.operators.completable
Execute an action after an onError, onComplete or a dispose event.
CompletableDoFinally(CompletableSource, Action) - Constructor for class io.reactivex.internal.operators.completable.CompletableDoFinally
 
CompletableDoOnEvent - Class in io.reactivex.internal.operators.completable
 
CompletableDoOnEvent(CompletableSource, Consumer<? super Throwable>) - Constructor for class io.reactivex.internal.operators.completable.CompletableDoOnEvent
 
CompletableEmitter - Interface in io.reactivex
Abstraction over an RxJava CompletableObserver that allows associating a resource with it.
CompletableEmpty - Class in io.reactivex.internal.operators.completable
 
CompletableError - Class in io.reactivex.internal.operators.completable
 
CompletableError(Throwable) - Constructor for class io.reactivex.internal.operators.completable.CompletableError
 
CompletableErrorSupplier - Class in io.reactivex.internal.operators.completable
 
CompletableErrorSupplier(Callable<? extends Throwable>) - Constructor for class io.reactivex.internal.operators.completable.CompletableErrorSupplier
 
CompletableFromAction - Class in io.reactivex.internal.operators.completable
 
CompletableFromAction(Action) - Constructor for class io.reactivex.internal.operators.completable.CompletableFromAction
 
CompletableFromCallable - Class in io.reactivex.internal.operators.completable
 
CompletableFromCallable(Callable<?>) - Constructor for class io.reactivex.internal.operators.completable.CompletableFromCallable
 
CompletableFromObservable<T> - Class in io.reactivex.internal.operators.completable
 
CompletableFromObservable(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.completable.CompletableFromObservable
 
CompletableFromPublisher<T> - Class in io.reactivex.internal.operators.completable
 
CompletableFromPublisher(Publisher<T>) - Constructor for class io.reactivex.internal.operators.completable.CompletableFromPublisher
 
CompletableFromRunnable - Class in io.reactivex.internal.operators.completable
 
CompletableFromRunnable(Runnable) - Constructor for class io.reactivex.internal.operators.completable.CompletableFromRunnable
 
CompletableFromSingle<T> - Class in io.reactivex.internal.operators.completable
 
CompletableFromSingle(SingleSource<T>) - Constructor for class io.reactivex.internal.operators.completable.CompletableFromSingle
 
CompletableFromUnsafeSource - Class in io.reactivex.internal.operators.completable
 
CompletableFromUnsafeSource(CompletableSource) - Constructor for class io.reactivex.internal.operators.completable.CompletableFromUnsafeSource
 
CompletableHide - Class in io.reactivex.internal.operators.completable
Hides the identity of the upstream Completable and its Disposable sent through onSubscribe.
CompletableHide(CompletableSource) - Constructor for class io.reactivex.internal.operators.completable.CompletableHide
 
CompletableLift - Class in io.reactivex.internal.operators.completable
 
CompletableLift(CompletableSource, CompletableOperator) - Constructor for class io.reactivex.internal.operators.completable.CompletableLift
 
CompletableMerge - Class in io.reactivex.internal.operators.completable
 
CompletableMerge(Publisher<? extends CompletableSource>, int, boolean) - Constructor for class io.reactivex.internal.operators.completable.CompletableMerge
 
CompletableMergeArray - Class in io.reactivex.internal.operators.completable
 
CompletableMergeArray(CompletableSource[]) - Constructor for class io.reactivex.internal.operators.completable.CompletableMergeArray
 
CompletableMergeDelayErrorArray - Class in io.reactivex.internal.operators.completable
 
CompletableMergeDelayErrorArray(CompletableSource[]) - Constructor for class io.reactivex.internal.operators.completable.CompletableMergeDelayErrorArray
 
CompletableMergeDelayErrorIterable - Class in io.reactivex.internal.operators.completable
 
CompletableMergeDelayErrorIterable(Iterable<? extends CompletableSource>) - Constructor for class io.reactivex.internal.operators.completable.CompletableMergeDelayErrorIterable
 
CompletableMergeIterable - Class in io.reactivex.internal.operators.completable
 
CompletableMergeIterable(Iterable<? extends CompletableSource>) - Constructor for class io.reactivex.internal.operators.completable.CompletableMergeIterable
 
CompletableNever - Class in io.reactivex.internal.operators.completable
 
CompletableObserveOn - Class in io.reactivex.internal.operators.completable
 
CompletableObserveOn(CompletableSource, Scheduler) - Constructor for class io.reactivex.internal.operators.completable.CompletableObserveOn
 
CompletableObserver - Interface in io.reactivex
Provides a mechanism for receiving push-based notification of a valueless completion or an error.
CompletableOnErrorComplete - Class in io.reactivex.internal.operators.completable
 
CompletableOnErrorComplete(CompletableSource, Predicate<? super Throwable>) - Constructor for class io.reactivex.internal.operators.completable.CompletableOnErrorComplete
 
CompletableOnSubscribe - Interface in io.reactivex
A functional interface that has a subscribe() method that receives an instance of a CompletableEmitter instance that allows pushing an event in a cancellation-safe manner.
CompletableOperator - Interface in io.reactivex
Interface to map/wrap a downstream observer to an upstream observer.
CompletablePeek - Class in io.reactivex.internal.operators.completable
 
CompletablePeek(CompletableSource, Consumer<? super Disposable>, Consumer<? super Throwable>, Action, Action, Action, Action) - Constructor for class io.reactivex.internal.operators.completable.CompletablePeek
 
CompletableResumeNext - Class in io.reactivex.internal.operators.completable
 
CompletableResumeNext(CompletableSource, Function<? super Throwable, ? extends CompletableSource>) - Constructor for class io.reactivex.internal.operators.completable.CompletableResumeNext
 
CompletableSource - Interface in io.reactivex
Represents a basic Completable source base interface, consumable via an CompletableObserver.
CompletableSubject - Class in io.reactivex.subjects
Represents a hot Completable-like source and consumer of events similar to Subjects.
CompletableSubscribeOn - Class in io.reactivex.internal.operators.completable
 
CompletableSubscribeOn(CompletableSource, Scheduler) - Constructor for class io.reactivex.internal.operators.completable.CompletableSubscribeOn
 
CompletableTimeout - Class in io.reactivex.internal.operators.completable
 
CompletableTimeout(CompletableSource, long, TimeUnit, Scheduler, CompletableSource) - Constructor for class io.reactivex.internal.operators.completable.CompletableTimeout
 
CompletableTimer - Class in io.reactivex.internal.operators.completable
Signals an onComplete event after the specified delay.
CompletableTimer(long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.completable.CompletableTimer
 
CompletableToFlowable<T> - Class in io.reactivex.internal.operators.completable
 
CompletableToFlowable(CompletableSource) - Constructor for class io.reactivex.internal.operators.completable.CompletableToFlowable
 
CompletableToObservable<T> - Class in io.reactivex.internal.operators.completable
Wraps a Completable and exposes it as an Observable.
CompletableToObservable(CompletableSource) - Constructor for class io.reactivex.internal.operators.completable.CompletableToObservable
 
CompletableToSingle<T> - Class in io.reactivex.internal.operators.completable
 
CompletableToSingle(CompletableSource, Callable<? extends T>, T) - Constructor for class io.reactivex.internal.operators.completable.CompletableToSingle
 
CompletableTransformer - Interface in io.reactivex
Convenience interface and callback used by the compose operator to turn a Completable into another Completable fluently.
CompletableUsing<R> - Class in io.reactivex.internal.operators.completable
 
CompletableUsing(Callable<R>, Function<? super R, ? extends CompletableSource>, Consumer<? super R>, boolean) - Constructor for class io.reactivex.internal.operators.completable.CompletableUsing
 
complete() - Static method in class io.reactivex.Completable
Returns a Completable instance that completes immediately when subscribed to.
complete(Observer<?>) - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
 
complete(MaybeObserver<?>) - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
 
complete(CompletableObserver) - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
 
complete(T) - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
Complete the target with a single value or indicate there is a value available in fusion mode.
complete() - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
Complete the target without any value.
complete(R) - Method in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
Signals the given value and an onComplete if the downstream is ready to receive the final value.
complete(T) - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
Completes this subscription by indicating the given value should be emitted when the first request arrives.
complete(Subscriber<?>) - Static method in enum io.reactivex.internal.subscriptions.EmptySubscription
Sets the empty subscription instance on the subscriber and then calls onComplete.
complete() - Static method in enum io.reactivex.internal.util.NotificationLite
Returns a complete notification.
completions - Variable in class io.reactivex.observers.BaseTestConsumer
The number of completions.
completions() - Method in class io.reactivex.observers.BaseTestConsumer
Returns the number of times onComplete was called.
compose(CompletableTransformer) - Method in class io.reactivex.Completable
Calls the given transformer function with this instance and returns the function's resulting Completable.
compose(FlowableTransformer<? super T, ? extends R>) - Method in class io.reactivex.Flowable
Transform a Publisher by applying a particular Transformer function to it.
compose(MaybeTransformer<? super T, ? extends R>) - Method in class io.reactivex.Maybe
Transform a Maybe by applying a particular Transformer function to it.
compose(ObservableTransformer<? super T, ? extends R>) - Method in class io.reactivex.Observable
Transform an ObservableSource by applying a particular Transformer function to it.
compose(ParallelTransformer<T, U>) - Method in class io.reactivex.parallel.ParallelFlowable
Allows composing operators, in assembly time, on top of this ParallelFlowable and returns another ParallelFlowable with composed features.
compose(SingleTransformer<? super T, ? extends R>) - Method in class io.reactivex.Single
Transform a Single by applying a particular Transformer function to it.
composeMessage(String) - Static method in class io.reactivex.internal.util.EndConsumerHelper
Builds the error message with the consumer class.
CompositeDisposable - Class in io.reactivex.disposables
A disposable container that can hold onto multiple other disposables and offers O(1) add and removal complexity.
CompositeDisposable() - Constructor for class io.reactivex.disposables.CompositeDisposable
Creates an empty CompositeDisposable.
CompositeDisposable(Disposable...) - Constructor for class io.reactivex.disposables.CompositeDisposable
Creates a CompositeDisposables with the given array of initial elements.
CompositeDisposable(Iterable<? extends Disposable>) - Constructor for class io.reactivex.disposables.CompositeDisposable
Creates a CompositeDisposables with the given Iterable sequence of initial elements.
CompositeException - Exception in io.reactivex.exceptions
Represents an exception that is a composite of one or more other exceptions.
CompositeException(Throwable...) - Constructor for exception io.reactivex.exceptions.CompositeException
Constructs a CompositeException with the given array of Throwables as the list of suppressed exceptions.
CompositeException(Iterable<? extends Throwable>) - Constructor for exception io.reactivex.exceptions.CompositeException
Constructs a CompositeException with the given array of Throwables as the list of suppressed exceptions.
COMPUTATION - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
The operator/class runs on RxJava's computation scheduler or takes timing information from it.
computation() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, shared Scheduler instance intended for computational work.
ComputationScheduler - Class in io.reactivex.internal.schedulers
Holds a fixed pool of worker threads and assigns them to requested Scheduler.Workers in a round-robin fashion.
ComputationScheduler() - Constructor for class io.reactivex.internal.schedulers.ComputationScheduler
Create a scheduler with pool size equal to the available processor count and using least-recent worker selection policy.
ComputationScheduler(ThreadFactory) - Constructor for class io.reactivex.internal.schedulers.ComputationScheduler
Create a scheduler with pool size equal to the available processor count and using least-recent worker selection policy.
concat(Iterable<? extends CompletableSource>) - Static method in class io.reactivex.Completable
Returns a Completable which completes only when all sources complete, one after another.
concat(Publisher<? extends CompletableSource>) - Static method in class io.reactivex.Completable
Returns a Completable which completes only when all sources complete, one after another.
concat(Publisher<? extends CompletableSource>, int) - Static method in class io.reactivex.Completable
Returns a Completable which completes only when all sources complete, one after another.
concat(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Concatenates elements of each Publisher provided via an Iterable sequence into a single sequence of elements without interleaving them.
concat(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by each of the Publishers emitted by the source Publisher, one after the other, without interleaving them.
concat(Publisher<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by each of the Publishers emitted by the source Publisher, one after the other, without interleaving them.
concat(Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by two Publishers, one after the other, without interleaving them.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by three Publishers, one after the other, without interleaving them.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by four Publishers, one after the other, without interleaving them.
concat(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Concatenate the single values, in a non-overlapping fashion, of the MaybeSource sources provided by an Iterable sequence.
concat(MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Returns a Flowable that emits the items emitted by two MaybeSources, one after the other.
concat(MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Returns a Flowable that emits the items emitted by three MaybeSources, one after the other.
concat(MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Returns a Flowable that emits the items emitted by four MaybeSources, one after the other.
concat(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Concatenate the single values, in a non-overlapping fashion, of the MaybeSource sources provided by a Publisher sequence.
concat(Publisher<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.Maybe
Concatenate the single values, in a non-overlapping fashion, of the MaybeSource sources provided by a Publisher sequence.
concat(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Concatenates elements of each ObservableSource provided via an Iterable sequence into a single sequence of elements without interleaving them.
concat(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by each of the ObservableSources emitted by the source ObservableSource, one after the other, without interleaving them.
concat(ObservableSource<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by each of the ObservableSources emitted by the source ObservableSource, one after the other, without interleaving them.
concat(ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by two ObservableSources, one after the other, without interleaving them.
concat(ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by three ObservableSources, one after the other, without interleaving them.
concat(ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by four ObservableSources, one after the other, without interleaving them.
concat(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided by an Iterable sequence.
concat(ObservableSource<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided by an Observable sequence.
concat(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided by a Publisher sequence.
concat(Publisher<? extends SingleSource<? extends T>>, int) - Static method in class io.reactivex.Single
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided by a Publisher sequence and prefetched by the specified amount.
concat(SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Returns a Flowable that emits the items emitted by two Singles, one after the other.
concat(SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Returns a Flowable that emits the items emitted by three Singles, one after the other.
concat(SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Returns a Flowable that emits the items emitted by four Singles, one after the other.
concatArray(CompletableSource...) - Static method in class io.reactivex.Completable
Returns a Completable which completes only when all sources complete, one after another.
concatArray(Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Concatenates a variable number of Publisher sources.
concatArray(MaybeSource<? extends T>...) - Static method in class io.reactivex.Maybe
Concatenate the single values, in a non-overlapping fashion, of the MaybeSource sources in the array.
concatArray(ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Concatenates a variable number of ObservableSource sources.
concatArray(SingleSource<? extends T>...) - Static method in class io.reactivex.Single
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided in an array.
concatArrayDelayError(Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Concatenates a variable number of Publisher sources and delays errors from any of them till all terminate.
concatArrayDelayError(MaybeSource<? extends T>...) - Static method in class io.reactivex.Maybe
Concatenates a variable number of MaybeSource sources and delays errors from any of them till all terminate.
concatArrayDelayError(ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Concatenates a variable number of ObservableSource sources and delays errors from any of them till all terminate.
concatArrayEager(Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Concatenates a sequence of Publishers eagerly into a single stream of values.
concatArrayEager(int, int, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Concatenates a sequence of Publishers eagerly into a single stream of values.
concatArrayEager(MaybeSource<? extends T>...) - Static method in class io.reactivex.Maybe
Concatenates a sequence of MaybeSource eagerly into a single stream of values.
concatArrayEager(ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Concatenates a sequence of ObservableSources eagerly into a single stream of values.
concatArrayEager(int, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Concatenates a sequence of ObservableSources eagerly into a single stream of values.
concatArrayEager(SingleSource<? extends T>...) - Static method in class io.reactivex.Single
Concatenates a sequence of SingleSource eagerly into a single stream of values.
concatDelayError(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Concatenates the Iterable sequence of Publishers into a single sequence by subscribing to each Publisher, one after the other, one at a time and delays any errors till the all inner Publishers terminate.
concatDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Concatenates the Publisher sequence of Publishers into a single sequence by subscribing to each inner Publisher, one after the other, one at a time and delays any errors till the all inner and the outer Publishers terminate.
concatDelayError(Publisher<? extends Publisher<? extends T>>, int, boolean) - Static method in class io.reactivex.Flowable
Concatenates the Publisher sequence of Publishers into a single sequence by subscribing to each inner Publisher, one after the other, one at a time and delays any errors till the all inner and the outer Publishers terminate.
concatDelayError(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Concatenates the Iterable sequence of MaybeSources into a single sequence by subscribing to each MaybeSource, one after the other, one at a time and delays any errors till the all inner MaybeSources terminate.
concatDelayError(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Concatenates the Publisher sequence of Publishers into a single sequence by subscribing to each inner Publisher, one after the other, one at a time and delays any errors till the all inner and the outer Publishers terminate.
concatDelayError(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Concatenates the Iterable sequence of ObservableSources into a single sequence by subscribing to each ObservableSource, one after the other, one at a time and delays any errors till the all inner ObservableSources terminate.
concatDelayError(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Concatenates the ObservableSource sequence of ObservableSources into a single sequence by subscribing to each inner ObservableSource, one after the other, one at a time and delays any errors till the all inner and the outer ObservableSources terminate.
concatDelayError(ObservableSource<? extends ObservableSource<? extends T>>, int, boolean) - Static method in class io.reactivex.Observable
Concatenates the ObservableSource sequence of ObservableSources into a single sequence by subscribing to each inner ObservableSource, one after the other, one at a time and delays any errors till the all inner and the outer ObservableSources terminate.
concatEager(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Concatenates a Publisher sequence of Publishers eagerly into a single stream of values.
concatEager(Publisher<? extends Publisher<? extends T>>, int, int) - Static method in class io.reactivex.Flowable
Concatenates a Publisher sequence of Publishers eagerly into a single stream of values.
concatEager(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Concatenates a sequence of Publishers eagerly into a single stream of values.
concatEager(Iterable<? extends Publisher<? extends T>>, int, int) - Static method in class io.reactivex.Flowable
Concatenates a sequence of Publishers eagerly into a single stream of values.
concatEager(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Concatenates a sequence of MaybeSources eagerly into a single stream of values.
concatEager(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Concatenates a Publisher sequence of MaybeSources eagerly into a single stream of values.
concatEager(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Concatenates an ObservableSource sequence of ObservableSources eagerly into a single stream of values.
concatEager(ObservableSource<? extends ObservableSource<? extends T>>, int, int) - Static method in class io.reactivex.Observable
Concatenates an ObservableSource sequence of ObservableSources eagerly into a single stream of values.
concatEager(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Concatenates a sequence of ObservableSources eagerly into a single stream of values.
concatEager(Iterable<? extends ObservableSource<? extends T>>, int, int) - Static method in class io.reactivex.Observable
Concatenates a sequence of ObservableSources eagerly into a single stream of values.
concatEager(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Concatenates a Publisher sequence of SingleSources eagerly into a single stream of values.
concatEager(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Concatenates a sequence of SingleSources eagerly into a single stream of values.
concatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.Flowable
Returns a new Flowable that emits items resulting from applying a function that you supply to each item emitted by the source Publisher, where that function returns a Publisher, and then emitting the items that result from concatenating those resulting Publishers.
concatMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.Flowable
Returns a new Flowable that emits items resulting from applying a function that you supply to each item emitted by the source Publisher, where that function returns a Publisher, and then emitting the items that result from concatenating those resulting Publishers.
concatMap(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Maybe
Returns a Maybe that is based on applying a specified function to the item emitted by the source Maybe, where that function returns a MaybeSource.
concatMap(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Observable
Returns a new Observable that emits items resulting from applying a function that you supply to each item emitted by the source ObservableSource, where that function returns an ObservableSource, and then emitting the items that result from concatenating those resulting ObservableSources.
concatMap(Function<? super T, ? extends ObservableSource<? extends R>>, int) - Method in class io.reactivex.Observable
Returns a new Observable that emits items resulting from applying a function that you supply to each item emitted by the source ObservableSource, where that function returns an ObservableSource, and then emitting the items that result from concatenating those resulting ObservableSources.
concatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.parallel.ParallelFlowable
Generates and concatenates Publishers on each 'rail', signalling errors immediately and generating 2 publishers upfront.
concatMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.parallel.ParallelFlowable
Generates and concatenates Publishers on each 'rail', signalling errors immediately and using the given prefetch amount for generating Publishers upfront.
concatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Flowable
Maps the upstream items into CompletableSources and subscribes to them one after the other completes.
concatMapCompletable(Function<? super T, ? extends CompletableSource>, int) - Method in class io.reactivex.Flowable
Maps the upstream items into CompletableSources and subscribes to them one after the other completes.
concatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Observable
Maps each element of the upstream Observable into CompletableSources, subscribes to them one at a time in order and waits until the upstream and all CompletableSources complete.
concatMapCompletable(Function<? super T, ? extends CompletableSource>, int) - Method in class io.reactivex.Observable
Maps each element of the upstream Observable into CompletableSources, subscribes to them one at a time in order and waits until the upstream and all CompletableSources complete.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Flowable
Maps the upstream items into CompletableSources and subscribes to them one after the other terminates, delaying all errors till both this Flowable and all inner CompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean) - Method in class io.reactivex.Flowable
Maps the upstream items into CompletableSources and subscribes to them one after the other terminates, optionally delaying all errors till both this Flowable and all inner CompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean, int) - Method in class io.reactivex.Flowable
Maps the upstream items into CompletableSources and subscribes to them one after the other terminates, optionally delaying all errors till both this Flowable and all inner CompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Observable
Maps the upstream items into CompletableSources and subscribes to them one after the other terminates, delaying all errors till both this Observable and all inner CompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean) - Method in class io.reactivex.Observable
Maps the upstream items into CompletableSources and subscribes to them one after the other terminates, optionally delaying all errors till both this Observable and all inner CompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean, int) - Method in class io.reactivex.Observable
Maps the upstream items into CompletableSources and subscribes to them one after the other terminates, optionally delaying all errors till both this Observable and all inner CompletableSources terminate.
concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.Flowable
Maps each of the items into a Publisher, subscribes to them one after the other, one at a time and emits their values in order while delaying any error from either this or any of the inner Publishers till all of them terminate.
concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, int, boolean) - Method in class io.reactivex.Flowable
Maps each of the items into a Publisher, subscribes to them one after the other, one at a time and emits their values in order while delaying any error from either this or any of the inner Publishers till all of them terminate.
concatMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Observable
Maps each of the items into an ObservableSource, subscribes to them one after the other, one at a time and emits their values in order while delaying any error from either this or any of the inner ObservableSources till all of them terminate.
concatMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, int, boolean) - Method in class io.reactivex.Observable
Maps each of the items into an ObservableSource, subscribes to them one after the other, one at a time and emits their values in order while delaying any error from either this or any of the inner ObservableSources till all of them terminate.
concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, boolean) - Method in class io.reactivex.parallel.ParallelFlowable
Generates and concatenates Publishers on each 'rail', optionally delaying errors and generating 2 publishers upfront.
concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, int, boolean) - Method in class io.reactivex.parallel.ParallelFlowable
Generates and concatenates Publishers on each 'rail', optionally delaying errors and using the given prefetch amount for generating Publishers upfront.
concatMapEager(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.Flowable
Maps a sequence of values into Publishers and concatenates these Publishers eagerly into a single Publisher.
concatMapEager(Function<? super T, ? extends Publisher<? extends R>>, int, int) - Method in class io.reactivex.Flowable
Maps a sequence of values into Publishers and concatenates these Publishers eagerly into a single Publisher.
concatMapEager(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Observable
Maps a sequence of values into ObservableSources and concatenates these ObservableSources eagerly into a single ObservableSource.
concatMapEager(Function<? super T, ? extends ObservableSource<? extends R>>, int, int) - Method in class io.reactivex.Observable
Maps a sequence of values into ObservableSources and concatenates these ObservableSources eagerly into a single ObservableSource.
concatMapEagerDelayError(Function<? super T, ? extends Publisher<? extends R>>, boolean) - Method in class io.reactivex.Flowable
Maps a sequence of values into Publishers and concatenates these Publishers eagerly into a single Publisher.
concatMapEagerDelayError(Function<? super T, ? extends Publisher<? extends R>>, int, int, boolean) - Method in class io.reactivex.Flowable
Maps a sequence of values into Publishers and concatenates these Publishers eagerly into a single Publisher.
concatMapEagerDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, boolean) - Method in class io.reactivex.Observable
Maps a sequence of values into ObservableSources and concatenates these ObservableSources eagerly into a single ObservableSource.
concatMapEagerDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, int, int, boolean) - Method in class io.reactivex.Observable
Maps a sequence of values into ObservableSources and concatenates these ObservableSources eagerly into a single ObservableSource.
concatMapIterable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Flowable
Returns a Flowable that concatenate each item emitted by the source Publisher with the values in an Iterable corresponding to that item that is generated by a selector.
concatMapIterable(Function<? super T, ? extends Iterable<? extends U>>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that concatenate each item emitted by the source Publisher with the values in an Iterable corresponding to that item that is generated by a selector.
concatMapIterable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Observable
Returns an Observable that concatenate each item emitted by the source ObservableSource with the values in an Iterable corresponding to that item that is generated by a selector.
concatMapIterable(Function<? super T, ? extends Iterable<? extends U>>, int) - Method in class io.reactivex.Observable
Returns an Observable that concatenate each item emitted by the source ObservableSource with the values in an Iterable corresponding to that item that is generated by a selector.
concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items into MaybeSources and subscribes to them one after the other succeeds or completes, emits their success value if available or terminates immediately if either this Flowable or the current inner MaybeSource fail.
concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, int) - Method in class io.reactivex.Flowable
Maps the upstream items into MaybeSources and subscribes to them one after the other succeeds or completes, emits their success value if available or terminates immediately if either this Flowable or the current inner MaybeSource fail.
concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items into MaybeSources and subscribes to them one after the other succeeds or completes, emits their success value if available or terminates immediately if either this Observable or the current inner MaybeSource fail.
concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, int) - Method in class io.reactivex.Observable
Maps the upstream items into MaybeSources and subscribes to them one after the other succeeds or completes, emits their success value if available or terminates immediately if either this Observable or the current inner MaybeSource fail.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items into MaybeSources and subscribes to them one after the other terminates, emits their success value if available and delaying all errors till both this Flowable and all inner MaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Method in class io.reactivex.Flowable
Maps the upstream items into MaybeSources and subscribes to them one after the other terminates, emits their success value if available and optionally delaying all errors till both this Flowable and all inner MaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean, int) - Method in class io.reactivex.Flowable
Maps the upstream items into MaybeSources and subscribes to them one after the other terminates, emits their success value if available and optionally delaying all errors till both this Flowable and all inner MaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items into MaybeSources and subscribes to them one after the other terminates, emits their success value if available and delaying all errors till both this Observable and all inner MaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Method in class io.reactivex.Observable
Maps the upstream items into MaybeSources and subscribes to them one after the other terminates, emits their success value if available and optionally delaying all errors till both this Observable and all inner MaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean, int) - Method in class io.reactivex.Observable
Maps the upstream items into MaybeSources and subscribes to them one after the other terminates, emits their success value if available and optionally delaying all errors till both this Observable and all inner MaybeSources terminate.
concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds, emits their success values or terminates immediately if either this Flowable or the current inner SingleSource fail.
concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, int) - Method in class io.reactivex.Flowable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds, emits their success values or terminates immediately if either this Flowable or the current inner SingleSource fail.
concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds, emits their success values or terminates immediately if either this Observable or the current inner SingleSource fail.
concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, int) - Method in class io.reactivex.Observable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds, emits their success values or terminates immediately if either this Observable or the current inner SingleSource fail.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds or fails, emits their success values and delays all errors till both this Flowable and all inner SingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Method in class io.reactivex.Flowable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds or fails, emits their success values and optionally delays all errors till both this Flowable and all inner SingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean, int) - Method in class io.reactivex.Flowable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds or fails, emits their success values and optionally delays errors till both this Flowable and all inner SingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds or fails, emits their success values and delays all errors till both this Observable and all inner SingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Method in class io.reactivex.Observable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds or fails, emits their success values and optionally delays all errors till both this Observable and all inner SingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean, int) - Method in class io.reactivex.Observable
Maps the upstream items into SingleSources and subscribes to them one after the other succeeds or fails, emits their success values and optionally delays errors till both this Observable and all inner SingleSources terminate.
concatWith(CompletableSource) - Method in class io.reactivex.Completable
Concatenates this Completable with another Completable.
concatWith(Publisher<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted from the current Publisher, then the next, one after the other, without interleaving them.
concatWith(SingleSource<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items from this Flowable followed by the success item or error event of the other SingleSource.
concatWith(MaybeSource<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items from this Flowable followed by the success item or terminal events of the other MaybeSource.
concatWith(CompletableSource) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items from this Flowable and when it completes normally, the other CompletableSource is subscribed to and the returned Flowable emits its terminal events.
concatWith(MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Returns a Flowable that emits the items emitted from the current MaybeSource, then the next, one after the other, without interleaving them.
concatWith(ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted from the current ObservableSource, then the next, one after the other, without interleaving them.
concatWith(SingleSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that emits the items from this Observable followed by the success item or error event of the other SingleSource.
concatWith(MaybeSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that emits the items from this Observable followed by the success item or terminal events of the other MaybeSource.
concatWith(CompletableSource) - Method in class io.reactivex.Observable
Returns an Observable that emits items from this Observable and when it completes normally, the other CompletableSource is subscribed to and the returned Observable emits its terminal events.
concatWith(SingleSource<? extends T>) - Method in class io.reactivex.Single
Returns a Flowable that emits the item emitted by the source Single, then the item emitted by the specified Single.
ConditionalSubscriber<T> - Interface in io.reactivex.internal.fuseable
A Subscriber with an additional onNextIf(T) method that tells the caller the specified value has been accepted or not.
connect(Consumer<? super Disposable>) - Method in class io.reactivex.flowables.ConnectableFlowable
Instructs the ConnectableFlowable to begin emitting the items from its underlying Flowable to its Subscribers.
connect() - Method in class io.reactivex.flowables.ConnectableFlowable
Instructs the ConnectableFlowable to begin emitting the items from its underlying Flowable to its Subscribers.
connect(Consumer<? super Disposable>) - Method in class io.reactivex.internal.operators.flowable.FlowablePublish
 
connect(Consumer<? super Disposable>) - Method in class io.reactivex.internal.operators.flowable.FlowableReplay
 
connect(Consumer<? super Disposable>) - Method in class io.reactivex.internal.operators.observable.ObservablePublish
 
connect(Consumer<? super Disposable>) - Method in class io.reactivex.internal.operators.observable.ObservableReplay
 
connect(Consumer<? super Disposable>) - Method in class io.reactivex.observables.ConnectableObservable
Instructs the ConnectableObservable to begin emitting the items from its underlying Observable to its Observers.
connect() - Method in class io.reactivex.observables.ConnectableObservable
Instructs the ConnectableObservable to begin emitting the items from its underlying Observable to its Observers.
ConnectableFlowable<T> - Class in io.reactivex.flowables
A ConnectableFlowable resembles an ordinary Flowable, except that it does not begin emitting items when it is subscribed to, but only when its ConnectableFlowable.connect(io.reactivex.functions.Consumer<? super io.reactivex.disposables.Disposable>) method is called.
ConnectableFlowable() - Constructor for class io.reactivex.flowables.ConnectableFlowable
 
ConnectableObservable<T> - Class in io.reactivex.observables
A ConnectableObservable resembles an ordinary Observable, except that it does not begin emitting items when it is subscribed to, but only when its ConnectableObservable.connect(io.reactivex.functions.Consumer<? super io.reactivex.disposables.Disposable>) method is called.
ConnectableObservable() - Constructor for class io.reactivex.observables.ConnectableObservable
 
ConnectConsumer - Class in io.reactivex.internal.util
Store the Disposable received from the connection.
ConnectConsumer() - Constructor for class io.reactivex.internal.util.ConnectConsumer
 
Consumer<T> - Interface in io.reactivex.functions
A functional interface (callback) that accepts a single value.
ConsumerSingleObserver<T> - Class in io.reactivex.internal.observers
 
ConsumerSingleObserver(Consumer<? super T>, Consumer<? super Throwable>) - Constructor for class io.reactivex.internal.observers.ConsumerSingleObserver
 
contains(Object) - Method in class io.reactivex.Flowable
Returns a Single that emits a Boolean that indicates whether the source Publisher emitted a specified item.
contains(Object) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
contains(Object) - Method in class io.reactivex.Maybe
Returns a Single that emits a Boolean that indicates whether the source Maybe emitted a specified item.
contains(Object) - Method in class io.reactivex.Observable
Returns a Single that emits a Boolean that indicates whether the source ObservableSource emitted a specified item.
contains(Object) - Method in class io.reactivex.Single
Signals true if the current Single signals a success value that is Object-equals with the value provided.
contains(Object, BiPredicate<Object, Object>) - Method in class io.reactivex.Single
Signals true if the current Single signals a success value that is equal with the value provided by calling a bi-predicate.
containsAll(Collection<?>) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
count() - Method in class io.reactivex.Flowable
Returns a Single that counts the total number of items emitted by the source Publisher and emits this count as a 64-bit Long.
count() - Method in class io.reactivex.Maybe
Returns a Maybe that counts the total number of items emitted (0 or 1) by the source Maybe and emits this count as a 64-bit Long.
count() - Method in class io.reactivex.Observable
Returns a Single that counts the total number of items emitted by the source ObservableSource and emits this count as a 64-bit Long.
create(CompletableOnSubscribe) - Static method in class io.reactivex.Completable
Provides an API (via a cold Completable) that bridges the reactive world with the callback-style world.
create(FlowableOnSubscribe<T>, BackpressureStrategy) - Static method in class io.reactivex.Flowable
Provides an API (via a cold Flowable) that bridges the reactive world with the callback-style, generally non-backpressured world.
create(Flowable<T>, int) - Static method in class io.reactivex.internal.operators.flowable.FlowablePublish
Creates a OperatorPublish instance to publish values of the given source observable.
create(Flowable<T>, int) - Static method in class io.reactivex.internal.operators.flowable.FlowableReplay
Creates a replaying ConnectableObservable with a size bound buffer.
create(Flowable<T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.internal.operators.flowable.FlowableReplay
Creates a replaying ConnectableObservable with a time bound buffer.
create(Flowable<T>, long, TimeUnit, Scheduler, int) - Static method in class io.reactivex.internal.operators.flowable.FlowableReplay
Creates a replaying ConnectableObservable with a size and time bound buffer.
create(Observer<? super T>) - Static method in class io.reactivex.internal.operators.maybe.MaybeToObservable
Creates a MaybeObserver wrapper around a Observer.
create(ObservableSource<T>) - Static method in class io.reactivex.internal.operators.observable.ObservablePublish
Creates a OperatorPublish instance to publish values of the given source observable.
create(ObservableSource<T>, int) - Static method in class io.reactivex.internal.operators.observable.ObservableReplay
Creates a replaying ConnectableObservable with a size bound buffer.
create(ObservableSource<T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.internal.operators.observable.ObservableReplay
Creates a replaying ConnectableObservable with a time bound buffer.
create(ObservableSource<T>, long, TimeUnit, Scheduler, int) - Static method in class io.reactivex.internal.operators.observable.ObservableReplay
Creates a replaying ConnectableObservable with a size and time bound buffer.
create(Observer<? super T>) - Static method in class io.reactivex.internal.operators.single.SingleToObservable
Creates a SingleObserver wrapper around a Observer.
create(ThreadFactory) - Static method in class io.reactivex.internal.schedulers.SchedulerPoolFactory
Creates a ScheduledExecutorService with the given factory.
create(MaybeOnSubscribe<T>) - Static method in class io.reactivex.Maybe
Provides an API (via a cold Maybe) that bridges the reactive world with the callback-style world.
create(ObservableOnSubscribe<T>) - Static method in class io.reactivex.Observable
Provides an API (via a cold Observable) that bridges the reactive world with the callback-style world.
create() - Static method in class io.reactivex.observers.TestObserver
Constructs a non-forwarding TestObserver.
create(Observer<? super T>) - Static method in class io.reactivex.observers.TestObserver
Constructs a forwarding TestObserver.
create() - Static method in class io.reactivex.processors.AsyncProcessor
Creates a new AsyncProcessor.
create() - Static method in class io.reactivex.processors.BehaviorProcessor
Creates a BehaviorProcessor without a default item.
create() - Static method in class io.reactivex.processors.MulticastProcessor
Constructs a fresh instance with the default Flowable.bufferSize() prefetch amount and no refCount-behavior.
create(boolean) - Static method in class io.reactivex.processors.MulticastProcessor
Constructs a fresh instance with the default Flowable.bufferSize() prefetch amount and the optional refCount-behavior.
create(int) - Static method in class io.reactivex.processors.MulticastProcessor
Constructs a fresh instance with the given prefetch amount and no refCount behavior.
create(int, boolean) - Static method in class io.reactivex.processors.MulticastProcessor
Constructs a fresh instance with the given prefetch amount and the optional refCount-behavior.
create() - Static method in class io.reactivex.processors.PublishProcessor
Constructs a PublishProcessor.
create() - Static method in class io.reactivex.processors.ReplayProcessor
Creates an unbounded ReplayProcessor.
create(int) - Static method in class io.reactivex.processors.ReplayProcessor
Creates an unbounded ReplayProcessor with the specified initial buffer capacity.
create() - Static method in class io.reactivex.processors.UnicastProcessor
Creates an UnicastSubject with an internal buffer capacity hint 16.
create(int) - Static method in class io.reactivex.processors.UnicastProcessor
Creates an UnicastProcessor with the given internal buffer capacity hint.
create(boolean) - Static method in class io.reactivex.processors.UnicastProcessor
Creates an UnicastProcessor with default internal buffer capacity hint and delay error flag.
create(int, Runnable) - Static method in class io.reactivex.processors.UnicastProcessor
Creates an UnicastProcessor with the given internal buffer capacity hint and a callback for the case when the single Subscriber cancels its subscription.
create(int, Runnable, boolean) - Static method in class io.reactivex.processors.UnicastProcessor
Creates an UnicastProcessor with the given internal buffer capacity hint, delay error flag and a callback for the case when the single Subscriber cancels its subscription.
create(SingleOnSubscribe<T>) - Static method in class io.reactivex.Single
Provides an API (via a cold Completable) that bridges the reactive world with the callback-style world.
create() - Static method in class io.reactivex.subjects.AsyncSubject
Creates a new AsyncProcessor.
create() - Static method in class io.reactivex.subjects.BehaviorSubject
Creates a BehaviorSubject without a default item.
create() - Static method in class io.reactivex.subjects.CompletableSubject
Creates a fresh CompletableSubject.
create() - Static method in class io.reactivex.subjects.MaybeSubject
Creates a fresh MaybeSubject.
create() - Static method in class io.reactivex.subjects.PublishSubject
Constructs a PublishSubject.
create() - Static method in class io.reactivex.subjects.ReplaySubject
Creates an unbounded replay subject.
create(int) - Static method in class io.reactivex.subjects.ReplaySubject
Creates an unbounded replay subject with the specified initial buffer capacity.
create() - Static method in class io.reactivex.subjects.SingleSubject
Creates a fresh SingleSubject.
create() - Static method in class io.reactivex.subjects.UnicastSubject
Creates an UnicastSubject with an internal buffer capacity hint 16.
create(int) - Static method in class io.reactivex.subjects.UnicastSubject
Creates an UnicastSubject with the given internal buffer capacity hint.
create(int, Runnable) - Static method in class io.reactivex.subjects.UnicastSubject
Creates an UnicastSubject with the given internal buffer capacity hint and a callback for the case when the single Subscriber cancels its subscription.
create(int, Runnable, boolean) - Static method in class io.reactivex.subjects.UnicastSubject
Creates an UnicastSubject with the given internal buffer capacity hint, delay error flag and a callback for the case when the single Subscriber cancels its subscription.
create(boolean) - Static method in class io.reactivex.subjects.UnicastSubject
Creates an UnicastSubject with an internal buffer capacity hint 16 and given delay error flag.
create() - Static method in class io.reactivex.subscribers.TestSubscriber
Creates a TestSubscriber with Long.MAX_VALUE initial request.
create(long) - Static method in class io.reactivex.subscribers.TestSubscriber
Creates a TestSubscriber with the given initial request.
create(Subscriber<? super T>) - Static method in class io.reactivex.subscribers.TestSubscriber
Constructs a forwarding TestSubscriber.
createArrayList(int) - Static method in class io.reactivex.internal.functions.Functions
 
createComputationScheduler(ThreadFactory) - Static method in class io.reactivex.plugins.RxJavaPlugins
Create an instance of the default Scheduler used for Schedulers.computation() except using threadFactory for thread creation.
createDefault(T) - Static method in class io.reactivex.processors.BehaviorProcessor
Creates a BehaviorProcessor that emits the last item it observed and all subsequent items to each Subscriber that subscribes to it.
createDefault(T) - Static method in class io.reactivex.subjects.BehaviorSubject
Creates a BehaviorSubject that emits the last item it observed and all subsequent items to each Observer that subscribes to it.
createFrom(Flowable<? extends T>) - Static method in class io.reactivex.internal.operators.flowable.FlowableReplay
Creates a replaying ConnectableObservable with an unbounded buffer.
createFrom(ObservableSource<? extends T>) - Static method in class io.reactivex.internal.operators.observable.ObservableReplay
Creates a replaying ConnectableObservable with an unbounded buffer.
createHashSet() - Static method in class io.reactivex.internal.functions.Functions
 
createIoScheduler(ThreadFactory) - Static method in class io.reactivex.plugins.RxJavaPlugins
Create an instance of the default Scheduler used for Schedulers.io() except using threadFactory for thread creation.
createNewThreadScheduler(ThreadFactory) - Static method in class io.reactivex.plugins.RxJavaPlugins
Create an instance of the default Scheduler used for Schedulers.newThread() except using threadFactory for thread creation.
createOnComplete() - Static method in class io.reactivex.Notification
Returns the empty and stateless shared instance of a notification representing an onComplete signal.
createOnError(Throwable) - Static method in class io.reactivex.Notification
Constructs an onError notification containing the error.
createOnNext(T) - Static method in class io.reactivex.Notification
Constructs an onNext notification containing the given value.
createQueue(int) - Static method in class io.reactivex.internal.util.QueueDrainHelper
Creates a queue: spsc-array if capacityHint is positive and spsc-linked-array if capacityHint is negative; in both cases, the capacity is the absolute value of prefetch.
createSingleScheduler(ThreadFactory) - Static method in class io.reactivex.plugins.RxJavaPlugins
Create an instance of the default Scheduler used for Schedulers.single() except using threadFactory for thread creation.
createWithSize(int) - Static method in class io.reactivex.processors.ReplayProcessor
Creates a size-bounded ReplayProcessor.
createWithSize(int) - Static method in class io.reactivex.subjects.ReplaySubject
Creates a size-bounded replay subject.
createWithTime(long, TimeUnit, Scheduler) - Static method in class io.reactivex.processors.ReplayProcessor
Creates a time-bounded ReplayProcessor.
createWithTime(long, TimeUnit, Scheduler) - Static method in class io.reactivex.subjects.ReplaySubject
Creates a time-bounded replay subject.
createWithTimeAndSize(long, TimeUnit, Scheduler, int) - Static method in class io.reactivex.processors.ReplayProcessor
Creates a time- and size-bounded ReplayProcessor.
createWithTimeAndSize(long, TimeUnit, Scheduler, int) - Static method in class io.reactivex.subjects.ReplaySubject
Creates a time- and size-bounded replay subject.
createWorker() - Method in class io.reactivex.internal.schedulers.ComputationScheduler
 
createWorker() - Method in class io.reactivex.internal.schedulers.ExecutorScheduler
 
createWorker() - Method in class io.reactivex.internal.schedulers.ImmediateThinScheduler
 
createWorker() - Method in class io.reactivex.internal.schedulers.IoScheduler
 
createWorker() - Method in class io.reactivex.internal.schedulers.NewThreadScheduler
 
createWorker() - Method in class io.reactivex.internal.schedulers.SchedulerWhen
 
createWorker() - Method in class io.reactivex.internal.schedulers.SingleScheduler
 
createWorker() - Method in class io.reactivex.internal.schedulers.TrampolineScheduler
 
createWorker() - Method in class io.reactivex.Scheduler
Retrieves or creates a new Scheduler.Worker that represents sequential execution of actions.
createWorker() - Method in class io.reactivex.schedulers.TestScheduler
 
createWorkers(int, SchedulerMultiWorkerSupport.WorkerCallback) - Method in class io.reactivex.internal.schedulers.ComputationScheduler
 
createWorkers(int, SchedulerMultiWorkerSupport.WorkerCallback) - Method in interface io.reactivex.internal.schedulers.SchedulerMultiWorkerSupport
Creates the given number of Scheduler.Worker instances that are possibly backed by distinct threads and calls the specified Consumer with them.
CUSTOM - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
A special value indicating the operator/class requires a scheduler to be manually specified.

D

debounce(Function<? super T, ? extends Publisher<U>>) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the source Publisher that are followed by another item within a computed debounce duration.
debounce(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the source Publisher that are followed by newer items before a timeout value expires.
debounce(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the source Publisher that are followed by newer items before a timeout value expires on a specified Scheduler.
debounce(Function<? super T, ? extends ObservableSource<U>>) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, except that it drops items emitted by the source ObservableSource that are followed by another item within a computed debounce duration.
debounce(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, except that it drops items emitted by the source ObservableSource that are followed by newer items before a timeout value expires.
debounce(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, except that it drops items emitted by the source ObservableSource that are followed by newer items before a timeout value expires on a specified Scheduler.
defaultIfEmpty(T) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by the source Publisher or a specified default item if the source Publisher is empty.
defaultIfEmpty(T) - Method in class io.reactivex.Maybe
Returns a Maybe that emits the item emitted by the source Maybe or a specified default item if the source Maybe is empty.
defaultIfEmpty(T) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by the source ObservableSource or a specified default item if the source ObservableSource is empty.
DefaultObserver<T> - Class in io.reactivex.observers
Abstract base implementation of an Observer with support for cancelling a subscription via DefaultObserver.cancel() (synchronously) and calls DefaultObserver.onStart() when the subscription happens.
DefaultObserver() - Constructor for class io.reactivex.observers.DefaultObserver
 
DefaultSubscriber<T> - Class in io.reactivex.subscribers
Abstract base implementation of a Subscriber with support for requesting via DefaultSubscriber.request(long), cancelling via via DefaultSubscriber.cancel() (both synchronously) and calls DefaultSubscriber.onStart() when the subscription happens.
DefaultSubscriber() - Constructor for class io.reactivex.subscribers.DefaultSubscriber
 
defer(Callable<? extends CompletableSource>) - Static method in class io.reactivex.Completable
Defers the subscription to a Completable instance returned by a supplier.
defer(Callable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Returns a Flowable that calls a Publisher factory to create a Publisher for each new Subscriber that subscribes.
defer(Callable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Calls a Callable for each individual MaybeObserver to return the actual MaybeSource source to be subscribed to.
defer(Callable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Returns an Observable that calls an ObservableSource factory to create an ObservableSource for each new Observer that subscribes.
defer(Callable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Calls a Callable for each individual SingleObserver to return the actual SingleSource to be subscribed to.
deferredRequest(AtomicReference<Subscription>, AtomicLong, long) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Atomically requests from the Subscription in the field if not null, otherwise accumulates the request amount in the requested field to be requested once the field is set to non-null.
DeferredScalarDisposable<T> - Class in io.reactivex.internal.observers
Represents a fuseable container for a single value.
DeferredScalarDisposable(Observer<? super T>) - Constructor for class io.reactivex.internal.observers.DeferredScalarDisposable
Constructs a DeferredScalarDisposable by wrapping the Observer.
DeferredScalarObserver<T,R> - Class in io.reactivex.internal.observers
A fuseable Observer that can generate 0 or 1 resulting value.
DeferredScalarObserver(Observer<? super R>) - Constructor for class io.reactivex.internal.observers.DeferredScalarObserver
Creates a DeferredScalarObserver instance and wraps a downstream Observer.
DeferredScalarSubscriber<T,R> - Class in io.reactivex.internal.subscribers
A subscriber, extending a DeferredScalarSubscription, that is unbounded-in and can generate 0 or 1 resulting value.
DeferredScalarSubscriber(Subscriber<? super R>) - Constructor for class io.reactivex.internal.subscribers.DeferredScalarSubscriber
Creates a DeferredScalarSubscriber instance and wraps a downstream Subscriber.
DeferredScalarSubscription<T> - Class in io.reactivex.internal.subscriptions
A subscription that signals a single value eventually.
DeferredScalarSubscription(Subscriber<? super T>) - Constructor for class io.reactivex.internal.subscriptions.DeferredScalarSubscription
Creates a DeferredScalarSubscription by wrapping the given Subscriber.
deferredSetOnce(AtomicReference<Subscription>, AtomicLong, Subscription) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Atomically sets the new Subscription on the field and requests any accumulated amount from the requested field.
delay(long, TimeUnit) - Method in class io.reactivex.Completable
Returns a Completable which delays the emission of the completion event by the given time.
delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.Completable
Returns a Completable which delays the emission of the completion event by the given time while running on the specified scheduler.
delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Completable
Returns a Completable which delays the emission of the completion event, and optionally the error as well, by the given time while running on the specified scheduler.
delay(Function<? super T, ? extends Publisher<U>>) - Method in class io.reactivex.Flowable
Returns a Flowable that delays the emissions of the source Publisher via another Publisher on a per-item basis.
delay(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by the source Publisher shifted forward in time by a specified delay.
delay(long, TimeUnit, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by the source Publisher shifted forward in time by a specified delay.
delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by the source Publisher shifted forward in time by a specified delay.
delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by the source Publisher shifted forward in time by a specified delay.
delay(Publisher<U>, Function<? super T, ? extends Publisher<V>>) - Method in class io.reactivex.Flowable
Returns a Flowable that delays the subscription to and emissions from the source Publisher via another Publisher on a per-item basis.
delay(long, TimeUnit) - Method in class io.reactivex.Maybe
Returns a Maybe that signals the events emitted by the source Maybe shifted forward in time by a specified delay.
delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.Maybe
Returns a Maybe that signals the events emitted by the source Maybe shifted forward in time by a specified delay running on the specified Scheduler.
delay(Publisher<U>) - Method in class io.reactivex.Maybe
Delays the emission of this Maybe until the given Publisher signals an item or completes.
delay(Function<? super T, ? extends ObservableSource<U>>) - Method in class io.reactivex.Observable
Returns an Observable that delays the emissions of the source ObservableSource via another ObservableSource on a per-item basis.
delay(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by the source ObservableSource shifted forward in time by a specified delay.
delay(long, TimeUnit, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by the source ObservableSource shifted forward in time by a specified delay.
delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by the source ObservableSource shifted forward in time by a specified delay.
delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by the source ObservableSource shifted forward in time by a specified delay.
delay(ObservableSource<U>, Function<? super T, ? extends ObservableSource<V>>) - Method in class io.reactivex.Observable
Returns an Observable that delays the subscription to and emissions from the source ObservableSource via another ObservableSource on a per-item basis.
delay(long, TimeUnit) - Method in class io.reactivex.Single
Delays the emission of the success signal from the current Single by the specified amount.
delay(long, TimeUnit, boolean) - Method in class io.reactivex.Single
Delays the emission of the success or error signal from the current Single by the specified amount.
delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.Single
Delays the emission of the success signal from the current Single by the specified amount.
delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Single
Delays the emission of the success or error signal from the current Single by the specified amount.
delaySubscription(Publisher<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that delays the subscription to this Publisher until the other Publisher emits an element or completes normally.
delaySubscription(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that delays the subscription to the source Publisher by a given amount of time.
delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that delays the subscription to the source Publisher by a given amount of time, both waiting and subscribing on a given Scheduler.
delaySubscription(Publisher<U>) - Method in class io.reactivex.Maybe
Returns a Maybe that delays the subscription to this Maybe until the other Publisher emits an element or completes normally.
delaySubscription(long, TimeUnit) - Method in class io.reactivex.Maybe
Returns a Maybe that delays the subscription to the source Maybe by a given amount of time.
delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.Maybe
Returns a Maybe that delays the subscription to the source Maybe by a given amount of time, both waiting and subscribing on a given Scheduler.
delaySubscription(ObservableSource<U>) - Method in class io.reactivex.Observable
Returns an Observable that delays the subscription to this Observable until the other Observable emits an element or completes normally.
delaySubscription(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that delays the subscription to the source ObservableSource by a given amount of time.
delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that delays the subscription to the source ObservableSource by a given amount of time, both waiting and subscribing on a given Scheduler.
delaySubscription(CompletableSource) - Method in class io.reactivex.Single
Delays the actual subscription to the current Single until the given other CompletableSource completes.
delaySubscription(SingleSource<U>) - Method in class io.reactivex.Single
Delays the actual subscription to the current Single until the given other SingleSource signals success.
delaySubscription(ObservableSource<U>) - Method in class io.reactivex.Single
Delays the actual subscription to the current Single until the given other ObservableSource signals its first value or completes.
delaySubscription(Publisher<U>) - Method in class io.reactivex.Single
Delays the actual subscription to the current Single until the given other Publisher signals its first value or completes.
delaySubscription(long, TimeUnit) - Method in class io.reactivex.Single
Delays the actual subscription to the current Single until the given time delay elapsed.
delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.Single
Delays the actual subscription to the current Single until the given time delay elapsed.
delete(Disposable) - Method in class io.reactivex.disposables.CompositeDisposable
Removes (but does not dispose) the given disposable if it is part of this container.
delete(Disposable) - Method in interface io.reactivex.internal.disposables.DisposableContainer
Removes (but does not dispose) the given disposable if it is part of this container.
delete(Disposable) - Method in class io.reactivex.internal.disposables.ListCompositeDisposable
 
dematerialize() - Method in class io.reactivex.Flowable
Returns a Flowable that reverses the effect of materialize by transforming the Notification objects emitted by the source Publisher into the items or notifications they represent.
dematerialize() - Method in class io.reactivex.Observable
Returns an Observable that reverses the effect of materialize by transforming the Notification objects emitted by the source ObservableSource into the items or notifications they represent.
Disposable - Interface in io.reactivex.disposables
Represents a disposable resource.
disposable - Variable in class io.reactivex.internal.util.ConnectConsumer
 
disposable(Disposable) - Static method in enum io.reactivex.internal.util.NotificationLite
Converts a Disposable into a notification value.
DisposableCompletableObserver - Class in io.reactivex.observers
An abstract CompletableObserver that allows asynchronous cancellation by implementing Disposable.
DisposableCompletableObserver() - Constructor for class io.reactivex.observers.DisposableCompletableObserver
 
DisposableContainer - Interface in io.reactivex.internal.disposables
Common interface to add and remove disposables from a container.
DisposableHelper - Enum in io.reactivex.internal.disposables
Utility methods for working with Disposables atomically.
DisposableLambdaObserver<T> - Class in io.reactivex.internal.observers
 
DisposableLambdaObserver(Observer<? super T>, Consumer<? super Disposable>, Action) - Constructor for class io.reactivex.internal.observers.DisposableLambdaObserver
 
DisposableMaybeObserver<T> - Class in io.reactivex.observers
An abstract MaybeObserver that allows asynchronous cancellation by implementing Disposable.
DisposableMaybeObserver() - Constructor for class io.reactivex.observers.DisposableMaybeObserver
 
DisposableObserver<T> - Class in io.reactivex.observers
An abstract Observer that allows asynchronous cancellation by implementing Disposable.
DisposableObserver() - Constructor for class io.reactivex.observers.DisposableObserver
 
Disposables - Class in io.reactivex.disposables
Utility class to help create disposables by wrapping other types.
DisposableSingleObserver<T> - Class in io.reactivex.observers
An abstract SingleObserver that allows asynchronous cancellation by implementing Disposable.
DisposableSingleObserver() - Constructor for class io.reactivex.observers.DisposableSingleObserver
 
DisposableSubscriber<T> - Class in io.reactivex.subscribers
An abstract Subscriber that allows asynchronous, external cancellation by implementing Disposable.
DisposableSubscriber() - Constructor for class io.reactivex.subscribers.DisposableSubscriber
 
dispose() - Method in class io.reactivex.disposables.CompositeDisposable
 
dispose() - Method in interface io.reactivex.disposables.Disposable
Dispose the resource, the operation should be idempotent.
dispose() - Method in class io.reactivex.disposables.SerialDisposable
 
dispose() - Method in class io.reactivex.internal.disposables.ArrayCompositeDisposable
 
dispose() - Method in class io.reactivex.internal.disposables.CancellableDisposable
 
dispose(AtomicReference<Disposable>) - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Atomically disposes the Disposable in the field if not already disposed.
dispose() - Method in enum io.reactivex.internal.disposables.DisposableHelper
 
dispose() - Method in enum io.reactivex.internal.disposables.EmptyDisposable
 
dispose() - Method in class io.reactivex.internal.disposables.ListCompositeDisposable
 
dispose() - Method in class io.reactivex.internal.disposables.SequentialDisposable
 
dispose() - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
dispose() - Method in class io.reactivex.internal.observers.BiConsumerSingleObserver
 
dispose() - Method in class io.reactivex.internal.observers.BlockingBaseObserver
 
dispose() - Method in class io.reactivex.internal.observers.BlockingObserver
 
dispose() - Method in class io.reactivex.internal.observers.CallbackCompletableObserver
 
dispose() - Method in class io.reactivex.internal.observers.ConsumerSingleObserver
 
dispose() - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
 
dispose() - Method in class io.reactivex.internal.observers.DeferredScalarObserver
 
dispose() - Method in class io.reactivex.internal.observers.DisposableLambdaObserver
 
dispose() - Method in class io.reactivex.internal.observers.EmptyCompletableObserver
 
dispose() - Method in class io.reactivex.internal.observers.ForEachWhileObserver
 
dispose() - Method in class io.reactivex.internal.observers.FutureObserver
 
dispose() - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
dispose() - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
dispose() - Method in class io.reactivex.internal.observers.LambdaObserver
 
dispose() - Method in class io.reactivex.internal.operators.flowable.FlowableReplay
 
dispose() - Method in class io.reactivex.internal.operators.maybe.MaybeCallbackObserver
 
dispose() - Method in class io.reactivex.internal.operators.observable.ObservableGroupBy.GroupByObserver
 
dispose() - Method in class io.reactivex.internal.operators.observable.ObservableReplay
 
dispose() - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
dispose() - Method in class io.reactivex.internal.operators.observable.ObserverResourceWrapper
 
dispose() - Method in class io.reactivex.internal.schedulers.ExecutorScheduler.ExecutorWorker
 
dispose() - Method in class io.reactivex.internal.schedulers.NewThreadWorker
 
dispose() - Method in class io.reactivex.internal.schedulers.ScheduledRunnable
 
dispose() - Method in class io.reactivex.internal.schedulers.SchedulerWhen
 
dispose() - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
dispose() - Method in class io.reactivex.internal.subscribers.ForEachWhileSubscriber
 
dispose() - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
dispose() - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
dispose() - Method in class io.reactivex.internal.subscriptions.ArrayCompositeSubscription
 
dispose() - Method in class io.reactivex.internal.subscriptions.AsyncSubscription
 
dispose() - Method in enum io.reactivex.internal.util.EmptyComponent
 
dispose() - Method in class io.reactivex.observers.DisposableCompletableObserver
 
dispose() - Method in class io.reactivex.observers.DisposableMaybeObserver
 
dispose() - Method in class io.reactivex.observers.DisposableObserver
 
dispose() - Method in class io.reactivex.observers.DisposableSingleObserver
 
dispose() - Method in class io.reactivex.observers.ResourceCompletableObserver
Cancels the main disposable (if any) and disposes the resources associated with this ResourceObserver (if any).
dispose() - Method in class io.reactivex.observers.ResourceMaybeObserver
Cancels the main disposable (if any) and disposes the resources associated with this ResourceObserver (if any).
dispose() - Method in class io.reactivex.observers.ResourceObserver
Cancels the main disposable (if any) and disposes the resources associated with this ResourceObserver (if any).
dispose() - Method in class io.reactivex.observers.ResourceSingleObserver
Cancels the main disposable (if any) and disposes the resources associated with this ResourceObserver (if any).
dispose() - Method in class io.reactivex.observers.SafeObserver
 
dispose() - Method in class io.reactivex.observers.SerializedObserver
 
dispose() - Method in class io.reactivex.observers.TestObserver
 
dispose() - Method in class io.reactivex.subscribers.DisposableSubscriber
 
dispose() - Method in class io.reactivex.subscribers.ResourceSubscriber
Cancels the subscription (if any) and disposes the resources associated with this AsyncObserver (if any).
dispose() - Method in class io.reactivex.subscribers.TestSubscriber
 
disposed() - Static method in class io.reactivex.disposables.Disposables
Returns a disposed Disposable instance.
distinct() - Method in class io.reactivex.Flowable
Returns a Flowable that emits all items emitted by the source Publisher that are distinct based on Object.equals(Object) comparison.
distinct(Function<? super T, K>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits all items emitted by the source Publisher that are distinct according to a key selector function and based on Object.equals(Object) comparison of the objects returned by the key selector function.
distinct(Function<? super T, K>, Callable<? extends Collection<? super K>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits all items emitted by the source Publisher that are distinct according to a key selector function and based on Object.equals(Object) comparison of the objects returned by the key selector function.
distinct() - Method in class io.reactivex.Observable
Returns an Observable that emits all items emitted by the source ObservableSource that are distinct based on Object.equals(Object) comparison.
distinct(Function<? super T, K>) - Method in class io.reactivex.Observable
Returns an Observable that emits all items emitted by the source ObservableSource that are distinct according to a key selector function and based on Object.equals(Object) comparison of the objects returned by the key selector function.
distinct(Function<? super T, K>, Callable<? extends Collection<? super K>>) - Method in class io.reactivex.Observable
Returns an Observable that emits all items emitted by the source ObservableSource that are distinct according to a key selector function and based on Object.equals(Object) comparison of the objects returned by the key selector function.
distinctUntilChanged() - Method in class io.reactivex.Flowable
Returns a Flowable that emits all items emitted by the source Publisher that are distinct from their immediate predecessors based on Object.equals(Object) comparison.
distinctUntilChanged(Function<? super T, K>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits all items emitted by the source Publisher that are distinct from their immediate predecessors, according to a key selector function and based on Object.equals(Object) comparison of those objects returned by the key selector function.
distinctUntilChanged(BiPredicate<? super T, ? super T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits all items emitted by the source Publisher that are distinct from their immediate predecessors when compared with each other via the provided comparator function.
distinctUntilChanged() - Method in class io.reactivex.Observable
Returns an Observable that emits all items emitted by the source ObservableSource that are distinct from their immediate predecessors based on Object.equals(Object) comparison.
distinctUntilChanged(Function<? super T, K>) - Method in class io.reactivex.Observable
Returns an Observable that emits all items emitted by the source ObservableSource that are distinct from their immediate predecessors, according to a key selector function and based on Object.equals(Object) comparison of those objects returned by the key selector function.
distinctUntilChanged(BiPredicate<? super T, ? super T>) - Method in class io.reactivex.Observable
Returns an Observable that emits all items emitted by the source ObservableSource that are distinct from their immediate predecessors when compared with each other via the provided comparator function.
doAfterNext(Consumer<? super T>) - Method in class io.reactivex.Flowable
Calls the specified consumer with the current item after this item has been emitted to the downstream.
doAfterNext(Consumer<? super T>) - Method in class io.reactivex.Observable
Calls the specified consumer with the current item after this item has been emitted to the downstream.
doAfterNext(Consumer<? super T>) - Method in class io.reactivex.parallel.ParallelFlowable
Call the specified consumer with the current element passing through any 'rail' after it has been delivered to downstream within the rail.
doAfterSuccess(Consumer<? super T>) - Method in class io.reactivex.Maybe
Calls the specified consumer with the success item after this item has been emitted to the downstream.
doAfterSuccess(Consumer<? super T>) - Method in class io.reactivex.Single
Calls the specified consumer with the success item after this item has been emitted to the downstream.
doAfterTerminate(Action) - Method in class io.reactivex.Completable
Returns a Completable instance that calls the given onTerminate callback after this Completable completes normally or with an exception.
doAfterTerminate(Action) - Method in class io.reactivex.Flowable
Registers an Action to be called when this Publisher invokes either onComplete or onError.
doAfterTerminate(Action) - Method in class io.reactivex.Maybe
Registers an Action to be called when this Maybe invokes either onSuccess, onComplete or onError.
doAfterTerminate(Action) - Method in class io.reactivex.Observable
Registers an Action to be called when this ObservableSource invokes either onComplete or onError.
doAfterTerminate(Action) - Method in class io.reactivex.Single
Registers an Action to be called after this Single invokes either onSuccess or onError.
doAfterTerminated(Action) - Method in class io.reactivex.parallel.ParallelFlowable
Run the specified Action when a 'rail' completes or signals an error.
doFinally(Action) - Method in class io.reactivex.Completable
Calls the specified action after this Completable signals onError or onComplete or gets disposed by the downstream.
doFinally(Action) - Method in class io.reactivex.Flowable
Calls the specified action after this Flowable signals onError or onCompleted or gets canceled by the downstream.
doFinally(Action) - Method in class io.reactivex.Maybe
Calls the specified action after this Maybe signals onSuccess, onError or onComplete or gets disposed by the downstream.
doFinally(Action) - Method in class io.reactivex.Observable
Calls the specified action after this Observable signals onError or onCompleted or gets disposed by the downstream.
doFinally(Action) - Method in class io.reactivex.Single
Calls the specified action after this Single signals onSuccess or onError or gets disposed by the downstream.
done - Variable in class io.reactivex.internal.observers.BasicFuseableObserver
Flag indicating no further onXXX event should be accepted.
done - Variable in class io.reactivex.internal.observers.QueueDrainObserver
 
done() - Method in class io.reactivex.internal.observers.QueueDrainObserver
 
done - Variable in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
Flag indicating no further onXXX event should be accepted.
done - Variable in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
Flag indicating no further onXXX event should be accepted.
done - Variable in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
done() - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
done() - Method in interface io.reactivex.internal.util.ObservableQueueDrain
 
done() - Method in interface io.reactivex.internal.util.QueueDrain
 
done - Variable in class io.reactivex.observers.BaseTestConsumer
The latch that indicates an onError or onComplete has been called.
doOnCancel(Action) - Method in class io.reactivex.Flowable
Calls the cancel Action if the downstream cancels the sequence.
doOnCancel(Action) - Method in class io.reactivex.parallel.ParallelFlowable
Run the specified Action when a 'rail' receives a cancellation.
doOnComplete(Action) - Method in class io.reactivex.Completable
Returns a Completable which calls the given onComplete callback if this Completable completes.
doOnComplete(Action) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it invokes an action when it calls onComplete.
doOnComplete(Action) - Method in class io.reactivex.Maybe
Modifies the source Maybe so that it invokes an action when it calls onComplete.
doOnComplete(Action) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes an action when it calls onComplete.
doOnComplete(Action) - Method in class io.reactivex.parallel.ParallelFlowable
Run the specified Action when a 'rail' completes.
doOnDispose(Action) - Method in class io.reactivex.Completable
Calls the shared Action if a CompletableObserver subscribed to the current Completable disposes the common Disposable it received via onSubscribe.
doOnDispose(Action) - Method in class io.reactivex.Maybe
Calls the shared Action if a MaybeObserver subscribed to the current Maybe disposes the common Disposable it received via onSubscribe.
doOnDispose(Action) - Method in class io.reactivex.Observable
Calls the dispose Action if the downstream disposes the sequence.
doOnDispose(Action) - Method in class io.reactivex.Single
Calls the shared Action if a SingleObserver subscribed to the current Single disposes the common Disposable it received via onSubscribe.
doOnEach(Consumer<? super Notification<T>>) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it invokes an action for each item it emits.
doOnEach(Subscriber<? super T>) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it notifies a Subscriber for each item and terminal event it emits.
doOnEach(Consumer<? super Notification<T>>) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes an action for each item it emits.
doOnEach(Observer<? super T>) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it notifies an Observer for each item and terminal event it emits.
doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.Completable
Returns a Completable which calls the given onError callback if this Completable emits an error.
doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it invokes an action if it calls onError.
doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.Maybe
Calls the shared consumer with the error sent via onError for each MaybeObserver that subscribes to the current Maybe.
doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes an action if it calls onError.
doOnError(Consumer<Throwable>) - Method in class io.reactivex.parallel.ParallelFlowable
Call the specified consumer with the exception passing through any 'rail'.
doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.Single
Calls the shared consumer with the error sent via onError for each SingleObserver that subscribes to the current Single.
doOnEvent(Consumer<? super Throwable>) - Method in class io.reactivex.Completable
Returns a Completable which calls the given onEvent callback with the (throwable) for an onError or (null) for an onComplete signal from this Completable before delivering said signal to the downstream.
doOnEvent(BiConsumer<? super T, ? super Throwable>) - Method in class io.reactivex.Maybe
Calls the given onEvent callback with the (success value, null) for an onSuccess, (null, throwable) for an onError or (null, null) for an onComplete signal from this Maybe before delivering said signal to the downstream.
doOnEvent(BiConsumer<? super T, ? super Throwable>) - Method in class io.reactivex.Single
Calls the shared consumer with the error sent via onError or the value via onSuccess for each SingleObserver that subscribes to the current Single.
doOnLifecycle(Consumer<? super Subscription>, LongConsumer, Action) - Method in class io.reactivex.Flowable
Calls the appropriate onXXX method (shared between all Subscribers) for the lifecycle events of the sequence (subscription, cancellation, requesting).
doOnLifecycle(Consumer<? super Disposable>, Action) - Method in class io.reactivex.Observable
Calls the appropriate onXXX method (shared between all Observer) for the lifecycle events of the sequence (subscription, cancellation, requesting).
doOnNext(Consumer<? super T>) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it invokes an action when it calls onNext.
doOnNext(Consumer<? super T>) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes an action when it calls onNext.
doOnNext(Consumer<? super T>) - Method in class io.reactivex.parallel.ParallelFlowable
Call the specified consumer with the current element passing through any 'rail'.
doOnNext(Consumer<? super T>, ParallelFailureHandling) - Method in class io.reactivex.parallel.ParallelFlowable
Call the specified consumer with the current element passing through any 'rail' and handles errors based on the given ParallelFailureHandling enumeration value.
doOnNext(Consumer<? super T>, BiFunction<? super Long, ? super Throwable, ParallelFailureHandling>) - Method in class io.reactivex.parallel.ParallelFlowable
Call the specified consumer with the current element passing through any 'rail' and handles errors based on the returned value by the handler function.
doOnRequest(LongConsumer) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it invokes the given action when it receives a request for more items.
doOnRequest(LongConsumer) - Method in class io.reactivex.parallel.ParallelFlowable
Call the specified consumer with the request amount if any rail receives a request.
doOnSubscribe(Consumer<? super Disposable>) - Method in class io.reactivex.Completable
Returns a Completable instance that calls the given onSubscribe callback with the disposable that child subscribers receive on subscription.
doOnSubscribe(Consumer<? super Subscription>) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it invokes the given action when it is subscribed from its subscribers.
doOnSubscribe(Consumer<? super Disposable>) - Method in class io.reactivex.Maybe
Calls the shared consumer with the Disposable sent through the onSubscribe for each MaybeObserver that subscribes to the current Maybe.
doOnSubscribe(Consumer<? super Disposable>) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes the given action when it is subscribed from its subscribers.
doOnSubscribe(Consumer<? super Subscription>) - Method in class io.reactivex.parallel.ParallelFlowable
Call the specified callback when a 'rail' receives a Subscription from its upstream.
doOnSubscribe(Consumer<? super Disposable>) - Method in class io.reactivex.Single
Calls the shared consumer with the Disposable sent through the onSubscribe for each SingleObserver that subscribes to the current Single.
doOnSuccess(Consumer<? super T>) - Method in class io.reactivex.Maybe
Calls the shared consumer with the success value sent via onSuccess for each MaybeObserver that subscribes to the current Maybe.
doOnSuccess(Consumer<? super T>) - Method in class io.reactivex.Single
Calls the shared consumer with the success value sent via onSuccess for each SingleObserver that subscribes to the current Single.
doOnTerminate(Action) - Method in class io.reactivex.Completable
Returns a Completable instance that calls the given onTerminate callback just before this Completable completes normally or with an exception.
doOnTerminate(Action) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it invokes an action when it calls onComplete or onError.
doOnTerminate(Action) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes an action when it calls onComplete or onError.
drain() - Method in interface io.reactivex.internal.observers.InnerQueuedObserverSupport
 
drain() - Method in interface io.reactivex.internal.subscribers.InnerQueuedSubscriberSupport
 
drainLoop(SimplePlainQueue<T>, Observer<? super U>, boolean, Disposable, ObservableQueueDrain<T, U>) - Static method in class io.reactivex.internal.util.QueueDrainHelper
 
drainMaxLoop(SimplePlainQueue<T>, Subscriber<? super U>, boolean, Disposable, QueueDrain<T, U>) - Static method in class io.reactivex.internal.util.QueueDrainHelper
Drain the queue but give up with an error if there aren't enough requests.

E

elementAt(long) - Method in class io.reactivex.Flowable
Returns a Maybe that emits the single item at a specified index in a sequence of emissions from this Flowable or completes if this Flowable sequence has fewer elements than index.
elementAt(long, T) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the item found at a specified index in a sequence of emissions from this Flowable, or a default item if that index is out of range.
elementAt(long) - Method in class io.reactivex.Observable
Returns a Maybe that emits the single item at a specified index in a sequence of emissions from this Observable or completes if this Observable signals fewer elements than index.
elementAt(long, T) - Method in class io.reactivex.Observable
Returns a Single that emits the item found at a specified index in a sequence of emissions from this Observable, or a default item if that index is out of range.
elementAtOrError(long) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the item found at a specified index in a sequence of emissions from this Flowable or signals a NoSuchElementException if this Flowable has fewer elements than index.
elementAtOrError(long) - Method in class io.reactivex.Observable
Returns a Single that emits the item found at a specified index in a sequence of emissions from this Observable or signals a NoSuchElementException if this Observable signals fewer elements than index.
Emitter<T> - Interface in io.reactivex
Base interface for emitting signals in a push-fashion in various generator-like source operators (create, generate).
empty() - Static method in class io.reactivex.disposables.Disposables
Returns a new, non-disposed Disposable instance.
empty() - Static method in class io.reactivex.Flowable
Returns a Flowable that emits no items to the Subscriber and immediately invokes its onComplete method.
empty() - Static method in class io.reactivex.Maybe
Returns a (singleton) Maybe instance that calls onComplete immediately.
empty() - Static method in class io.reactivex.Observable
Returns an Observable that emits no items to the Observer and immediately invokes its onComplete method.
EMPTY_ACTION - Static variable in class io.reactivex.internal.functions.Functions
 
EMPTY_LONG_CONSUMER - Static variable in class io.reactivex.internal.functions.Functions
 
EMPTY_RUNNABLE - Static variable in class io.reactivex.internal.functions.Functions
 
EmptyCompletableObserver - Class in io.reactivex.internal.observers
 
EmptyCompletableObserver() - Constructor for class io.reactivex.internal.observers.EmptyCompletableObserver
 
EmptyComponent - Enum in io.reactivex.internal.util
Singleton implementing many interfaces as empty.
emptyConsumer() - Static method in class io.reactivex.internal.functions.Functions
Returns an empty consumer that does nothing.
EmptyDisposable - Enum in io.reactivex.internal.disposables
Represents a stateless empty Disposable that reports being always empty and disposed.
EmptySubscription - Enum in io.reactivex.internal.subscriptions
An empty subscription that does nothing other than validates the request amount.
emptyThrower() - Static method in class io.reactivex.internal.operators.single.SingleInternalHelper
 
EndConsumerHelper - Class in io.reactivex.internal.util
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.
enter() - Method in class io.reactivex.internal.observers.QueueDrainObserver
 
enter() - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
enter() - Method in interface io.reactivex.internal.util.ObservableQueueDrain
 
enter() - Method in interface io.reactivex.internal.util.QueueDrain
 
equals(Object, Object) - Static method in class io.reactivex.internal.functions.ObjectHelper
Compares two potentially null objects with each other using Object.equals.
equals(Object) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
equals(Object) - Method in class io.reactivex.Notification
 
equals(Object) - Method in class io.reactivex.schedulers.Timed
 
equals(SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Compares two SingleSources and emits true if they emit the same value (compared via Object.equals).
equalsPredicate() - Static method in class io.reactivex.internal.functions.ObjectHelper
Returns a BiPredicate that compares its parameters via Objects.equals().
equalsWith(T) - Static method in class io.reactivex.internal.functions.Functions
 
error(Callable<? extends Throwable>) - Static method in class io.reactivex.Completable
Creates a Completable which calls the given error supplier for each subscriber and emits its returned Throwable.
error(Throwable) - Static method in class io.reactivex.Completable
Creates a Completable instance that emits the given Throwable exception to subscribers.
error(Callable<? extends Throwable>) - Static method in class io.reactivex.Flowable
Returns a Flowable that invokes a Subscriber's onError method when the Subscriber subscribes to it.
error(Throwable) - Static method in class io.reactivex.Flowable
Returns a Flowable that invokes a Subscriber's onError method when the Subscriber subscribes to it.
error(Throwable, Observer<?>) - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
 
error(Throwable, CompletableObserver) - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
 
error(Throwable, SingleObserver<?>) - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
 
error(Throwable, MaybeObserver<?>) - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
 
error(Throwable) - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
Complete the target with an error signal.
error - Variable in class io.reactivex.internal.observers.QueueDrainObserver
 
error() - Method in class io.reactivex.internal.observers.QueueDrainObserver
 
error - Variable in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
error() - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
error(Throwable, Subscriber<?>) - Static method in enum io.reactivex.internal.subscriptions.EmptySubscription
Sets the empty subscription instance on the subscriber and then calls onError with the supplied error.
error - Variable in class io.reactivex.internal.util.BlockingIgnoringReceiver
 
error(Throwable) - Static method in enum io.reactivex.internal.util.NotificationLite
Converts a Throwable into a notification value.
error() - Method in interface io.reactivex.internal.util.ObservableQueueDrain
 
error() - Method in interface io.reactivex.internal.util.QueueDrain
 
error(Throwable) - Static method in class io.reactivex.Maybe
Returns a Maybe that invokes a subscriber's onError method when the subscriber subscribes to it.
error(Callable<? extends Throwable>) - Static method in class io.reactivex.Maybe
Returns a Maybe that invokes a MaybeObserver's onError method when the MaybeObserver subscribes to it.
error(Callable<? extends Throwable>) - Static method in class io.reactivex.Observable
Returns an Observable that invokes an Observer's onError method when the Observer subscribes to it.
error(Throwable) - Static method in class io.reactivex.Observable
Returns an Observable that invokes an Observer's onError method when the Observer subscribes to it.
error(Callable<? extends Throwable>) - Static method in class io.reactivex.Single
Signals a Throwable returned by the callback function for each individual SingleObserver.
error(Throwable) - Static method in class io.reactivex.Single
Returns a Single that invokes a subscriber's onError method when the subscriber subscribes to it.
ERROR_CONSUMER - Static variable in class io.reactivex.internal.functions.Functions
 
errorCount() - Method in class io.reactivex.observers.BaseTestConsumer
Returns the number of onError exceptions received.
ErrorMode - Enum in io.reactivex.internal.util
Indicates when an error from the main source should be reported.
errors - Variable in class io.reactivex.observers.BaseTestConsumer
The list of errors received.
errors() - Method in class io.reactivex.observers.BaseTestConsumer
Returns a shared list of received onError exceptions.
establishedFusionMode - Variable in class io.reactivex.observers.BaseTestConsumer
 
ExceptionHelper - Class in io.reactivex.internal.util
Terminal atomics for Throwable containers.
Exceptions - Class in io.reactivex.exceptions
Utility class to help propagate checked exceptions and rethrow exceptions designated as fatal.
ExecutorScheduler - Class in io.reactivex.internal.schedulers
Wraps an Executor and provides the Scheduler API over it.
ExecutorScheduler(Executor) - Constructor for class io.reactivex.internal.schedulers.ExecutorScheduler
 
ExecutorScheduler.ExecutorWorker - Class in io.reactivex.internal.schedulers
 
ExecutorWorker(Executor) - Constructor for class io.reactivex.internal.schedulers.ExecutorScheduler.ExecutorWorker
 
Experimental - Annotation Type in io.reactivex.annotations
Indicates the feature is in experimental state: its existence, signature or behavior might change without warning from one release to the next.

F

fail(Throwable) - Method in class io.reactivex.internal.observers.BasicFuseableObserver
Rethrows the throwable if it is a fatal exception or calls BasicFuseableObserver.onError(Throwable).
fail(Throwable) - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
Rethrows the throwable if it is a fatal exception or calls BasicFuseableConditionalSubscriber.onError(Throwable).
fail(Throwable) - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
Rethrows the throwable if it is a fatal exception or calls BasicFuseableSubscriber.onError(Throwable).
fail(String) - Method in class io.reactivex.observers.BaseTestConsumer
Fail with the given message and add the sequence of errors as suppressed ones.
fastEnter() - Method in class io.reactivex.internal.observers.QueueDrainObserver
 
fastEnter() - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
fastPathEmit(U, boolean, Disposable) - Method in class io.reactivex.internal.observers.QueueDrainObserver
 
fastPathEmitMax(U, boolean, Disposable) - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
fastPathOrderedEmit(U, boolean, Disposable) - Method in class io.reactivex.internal.observers.QueueDrainObserver
Makes sure the fast-path emits in order.
fastPathOrderedEmitMax(U, boolean, Disposable) - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
filter(Predicate<? super T>) - Method in class io.reactivex.Flowable
Filters items emitted by a Publisher by only emitting those that satisfy a specified predicate.
filter(Predicate<? super T>) - Method in class io.reactivex.Maybe
Filters the success item of the Maybe via a predicate function and emitting it if the predicate returns true, completing otherwise.
filter(Predicate<? super T>) - Method in class io.reactivex.Observable
Filters items emitted by an ObservableSource by only emitting those that satisfy a specified predicate.
filter(Predicate<? super T>) - Method in class io.reactivex.parallel.ParallelFlowable
Filters the source values on each 'rail'.
filter(Predicate<? super T>, ParallelFailureHandling) - Method in class io.reactivex.parallel.ParallelFlowable
Filters the source values on each 'rail' and handles errors based on the given ParallelFailureHandling enumeration value.
filter(Predicate<? super T>, BiFunction<? super Long, ? super Throwable, ParallelFailureHandling>) - Method in class io.reactivex.parallel.ParallelFlowable
Filters the source values on each 'rail' and handles errors based on the returned value by the handler function.
filter(Predicate<? super T>) - Method in class io.reactivex.Single
Filters the success item of the Single via a predicate function and emitting it if the predicate returns true, completing otherwise.
first(T) - Method in class io.reactivex.Flowable
Returns a Single that emits only the very first item emitted by this Flowable, or a default item if this Flowable completes without emitting anything.
first(T) - Method in class io.reactivex.Observable
Returns a Single that emits only the very first item emitted by the source ObservableSource, or a default item if the source ObservableSource completes without emitting any items.
firstElement() - Method in class io.reactivex.Flowable
Returns a Maybe that emits only the very first item emitted by this Flowable or completes if this Flowable is empty.
firstElement() - Method in class io.reactivex.Observable
Returns a Maybe that emits only the very first item emitted by the source ObservableSource, or completes if the source ObservableSource is empty.
firstOrError() - Method in class io.reactivex.Flowable
Returns a Single that emits only the very first item emitted by this Flowable or signals a NoSuchElementException if this Flowable is empty.
firstOrError() - Method in class io.reactivex.Observable
Returns a Single that emits only the very first item emitted by this Observable or signals a NoSuchElementException if this Observable is empty.
flatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items based on applying a function that you supply to each item emitted by the source Publisher, where that function returns a Publisher, and then merging those resulting Publishers and emitting the results of this merger.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items based on applying a function that you supply to each item emitted by the source Publisher, where that function returns a Publisher, and then merging those resulting Publishers and emitting the results of this merger.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items based on applying a function that you supply to each item emitted by the source Publisher, where that function returns a Publisher, and then merging those resulting Publishers and emitting the results of this merger, while limiting the maximum number of concurrent subscriptions to these Publishers.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items based on applying a function that you supply to each item emitted by the source Publisher, where that function returns a Publisher, and then merging those resulting Publishers and emitting the results of this merger, while limiting the maximum number of concurrent subscriptions to these Publishers.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean, int, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items based on applying a function that you supply to each item emitted by the source Publisher, where that function returns a Publisher, and then merging those resulting Publishers and emitting the results of this merger, while limiting the maximum number of concurrent subscriptions to these Publishers.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, Function<? super Throwable, ? extends Publisher<? extends R>>, Callable<? extends Publisher<? extends R>>) - Method in class io.reactivex.Flowable
Returns a Flowable that applies a function to each item emitted or notification raised by the source Publisher and then flattens the Publishers returned from these functions and emits the resulting items.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, Function<Throwable, ? extends Publisher<? extends R>>, Callable<? extends Publisher<? extends R>>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that applies a function to each item emitted or notification raised by the source Publisher and then flattens the Publishers returned from these functions and emits the resulting items, while limiting the maximum number of concurrent subscriptions to these Publishers.
flatMap(Function<? super T, ? extends Publisher<? extends U>>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the source Publisher and a specified collection Publisher.
flatMap(Function<? super T, ? extends Publisher<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the source Publisher and a specified collection Publisher.
flatMap(Function<? super T, ? extends Publisher<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, boolean, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the source Publisher and a specified collection Publisher, while limiting the maximum number of concurrent subscriptions to these Publishers.
flatMap(Function<? super T, ? extends Publisher<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, boolean, int, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the source Publisher and a specified collection Publisher, while limiting the maximum number of concurrent subscriptions to these Publishers.
flatMap(Function<? super T, ? extends Publisher<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the source Publisher and a specified collection Publisher, while limiting the maximum number of concurrent subscriptions to these Publishers.
flatMap(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Maybe
Returns a Maybe that is based on applying a specified function to the item emitted by the source Maybe, where that function returns a MaybeSource.
flatMap(Function<? super T, ? extends MaybeSource<? extends R>>, Function<? super Throwable, ? extends MaybeSource<? extends R>>, Callable<? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Maybe
Maps the onSuccess, onError or onComplete signals of this Maybe into MaybeSource and emits that MaybeSource's signals.
flatMap(Function<? super T, ? extends MaybeSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified function to the pair of values emitted by the source Maybe and a specified mapped MaybeSource.
flatMap(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Observable
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source ObservableSource, where that function returns an ObservableSource, and then merging those resulting ObservableSources and emitting the results of this merger.
flatMap(Function<? super T, ? extends ObservableSource<? extends R>>, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source ObservableSource, where that function returns an ObservableSource, and then merging those resulting ObservableSources and emitting the results of this merger.
flatMap(Function<? super T, ? extends ObservableSource<? extends R>>, boolean, int) - Method in class io.reactivex.Observable
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source ObservableSource, where that function returns an ObservableSource, and then merging those resulting ObservableSources and emitting the results of this merger, while limiting the maximum number of concurrent subscriptions to these ObservableSources.
flatMap(Function<? super T, ? extends ObservableSource<? extends R>>, boolean, int, int) - Method in class io.reactivex.Observable
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source ObservableSource, where that function returns an ObservableSource, and then merging those resulting ObservableSources and emitting the results of this merger, while limiting the maximum number of concurrent subscriptions to these ObservableSources.
flatMap(Function<? super T, ? extends ObservableSource<? extends R>>, Function<? super Throwable, ? extends ObservableSource<? extends R>>, Callable<? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Observable
Returns an Observable that applies a function to each item emitted or notification raised by the source ObservableSource and then flattens the ObservableSources returned from these functions and emits the resulting items.
flatMap(Function<? super T, ? extends ObservableSource<? extends R>>, Function<Throwable, ? extends ObservableSource<? extends R>>, Callable<? extends ObservableSource<? extends R>>, int) - Method in class io.reactivex.Observable
Returns an Observable that applies a function to each item emitted or notification raised by the source ObservableSource and then flattens the ObservableSources returned from these functions and emits the resulting items, while limiting the maximum number of concurrent subscriptions to these ObservableSources.
flatMap(Function<? super T, ? extends ObservableSource<? extends R>>, int) - Method in class io.reactivex.Observable
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source ObservableSource, where that function returns an ObservableSource, and then merging those resulting ObservableSources and emitting the results of this merger, while limiting the maximum number of concurrent subscriptions to these ObservableSources.
flatMap(Function<? super T, ? extends ObservableSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source ObservableSource and a specified collection ObservableSource.
flatMap(Function<? super T, ? extends ObservableSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source ObservableSource and a specified collection ObservableSource.
flatMap(Function<? super T, ? extends ObservableSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, boolean, int) - Method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source ObservableSource and a specified collection ObservableSource, while limiting the maximum number of concurrent subscriptions to these ObservableSources.
flatMap(Function<? super T, ? extends ObservableSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, boolean, int, int) - Method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source ObservableSource and a specified collection ObservableSource, while limiting the maximum number of concurrent subscriptions to these ObservableSources.
flatMap(Function<? super T, ? extends ObservableSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, int) - Method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source ObservableSource and a specified collection ObservableSource, while limiting the maximum number of concurrent subscriptions to these ObservableSources.
flatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.parallel.ParallelFlowable
Generates and flattens Publishers on each 'rail'.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean) - Method in class io.reactivex.parallel.ParallelFlowable
Generates and flattens Publishers on each 'rail', optionally delaying errors.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean, int) - Method in class io.reactivex.parallel.ParallelFlowable
Generates and flattens Publishers on each 'rail', optionally delaying errors and having a total number of simultaneous subscriptions to the inner Publishers.
flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean, int, int) - Method in class io.reactivex.parallel.ParallelFlowable
Generates and flattens Publishers on each 'rail', optionally delaying errors, having a total number of simultaneous subscriptions to the inner Publishers and using the given prefetch amount for the inner Publishers.
flatMap(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Single
Returns a Single that is based on applying a specified function to the item emitted by the source Single, where that function returns a SingleSource.
flatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Flowable
Maps each element of the upstream Flowable into CompletableSources, subscribes to them and waits until the upstream and all CompletableSources complete.
flatMapCompletable(Function<? super T, ? extends CompletableSource>, boolean, int) - Method in class io.reactivex.Flowable
Maps each element of the upstream Flowable into CompletableSources, subscribes to them and waits until the upstream and all CompletableSources complete, optionally delaying all errors.
flatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Maybe
Returns a Completable that completes based on applying a specified function to the item emitted by the source Maybe, where that function returns a Completable.
flatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Observable
Maps each element of the upstream Observable into CompletableSources, subscribes to them and waits until the upstream and all CompletableSources complete.
flatMapCompletable(Function<? super T, ? extends CompletableSource>, boolean) - Method in class io.reactivex.Observable
Maps each element of the upstream Observable into CompletableSources, subscribes to them and waits until the upstream and all CompletableSources complete, optionally delaying all errors.
flatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Single
Returns a Completable that completes based on applying a specified function to the item emitted by the source Single, where that function returns a Completable.
flatMapIntoIterable(Function<? super T, ? extends Iterable<? extends U>>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
flatMapIntoIterable(Function<? super T, ? extends Iterable<? extends U>>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
flatMapIterable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Flowable
Returns a Flowable that merges each item emitted by the source Publisher with the values in an Iterable corresponding to that item that is generated by a selector.
flatMapIterable(Function<? super T, ? extends Iterable<? extends U>>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that merges each item emitted by the source Publisher with the values in an Iterable corresponding to that item that is generated by a selector.
flatMapIterable(Function<? super T, ? extends Iterable<? extends U>>, BiFunction<? super T, ? super U, ? extends V>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the results of applying a function to the pair of values from the source Publisher and an Iterable corresponding to that item that is generated by a selector.
flatMapIterable(Function<? super T, ? extends Iterable<? extends U>>, BiFunction<? super T, ? super U, ? extends V>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that merges each item emitted by the source Publisher with the values in an Iterable corresponding to that item that is generated by a selector, while limiting the number of concurrent subscriptions to these Publishers.
flatMapIterable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Observable
Returns an Observable that merges each item emitted by the source ObservableSource with the values in an Iterable corresponding to that item that is generated by a selector.
flatMapIterable(Function<? super T, ? extends Iterable<? extends U>>, BiFunction<? super T, ? super U, ? extends V>) - Method in class io.reactivex.Observable
Returns an Observable that emits the results of applying a function to the pair of values from the source ObservableSource and an Iterable corresponding to that item that is generated by a selector.
flatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps each element of the upstream Flowable into MaybeSources, subscribes to all of them and merges their onSuccess values, in no particular order, into a single Flowable sequence.
flatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, boolean, int) - Method in class io.reactivex.Flowable
Maps each element of the upstream Flowable into MaybeSources, subscribes to at most maxConcurrency MaybeSources at a time and merges their onSuccess values, in no particular order, into a single Flowable sequence, optionally delaying all errors.
flatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps each element of the upstream Observable into MaybeSources, subscribes to all of them and merges their onSuccess values, in no particular order, into a single Observable sequence.
flatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Method in class io.reactivex.Observable
Maps each element of the upstream Observable into MaybeSources, subscribes to them and merges their onSuccess values, in no particular order, into a single Observable sequence, optionally delaying all errors.
flatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Single
Returns a Maybe that is based on applying a specified function to the item emitted by the source Single, where that function returns a MaybeSource.
flatMapObservable(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Maybe
Returns an Observable that is based on applying a specified function to the item emitted by the source Maybe, where that function returns an ObservableSource.
flatMapObservable(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Single
Returns an Observable that is based on applying a specified function to the item emitted by the source Single, where that function returns an ObservableSource.
flatMapPublisher(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.Maybe
Returns a Flowable that emits items based on applying a specified function to the item emitted by the source Maybe, where that function returns a Publisher.
flatMapPublisher(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.Single
Returns 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.
flatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps each element of the upstream Flowable into SingleSources, subscribes to all of them and merges their onSuccess values, in no particular order, into a single Flowable sequence.
flatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, boolean, int) - Method in class io.reactivex.Flowable
Maps each element of the upstream Flowable into SingleSources, subscribes to at most maxConcurrency SingleSources at a time and merges their onSuccess values, in no particular order, into a single Flowable sequence, optionally delaying all errors.
flatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Maybe
Returns a Single based on applying a specified function to the item emitted by the source Maybe, where that function returns a Single.
flatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Observable
Maps each element of the upstream Observable into SingleSources, subscribes to all of them and merges their onSuccess values, in no particular order, into a single Observable sequence.
flatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Method in class io.reactivex.Observable
Maps each element of the upstream Observable into SingleSources, subscribes to them and merges their onSuccess values, in no particular order, into a single Observable sequence, optionally delaying all errors.
flatMapSingleElement(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Maybe
Returns a Maybe based on applying a specified function to the item emitted by the source Maybe, where that function returns a Single.
flatMapWithCombiner(Function<? super T, ? extends Publisher<? extends U>>, BiFunction<? super T, ? super U, ? extends R>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
flatMapWithCombiner(Function<? super T, ? extends ObservableSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
flatten(Throwable) - Static method in class io.reactivex.internal.util.ExceptionHelper
Returns a flattened list of Throwables from tree-like CompositeException chain.
flattenAsFlowable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Maybe
Returns a Flowable that merges each item emitted by the source Maybe with the values in an Iterable corresponding to that item that is generated by a selector.
flattenAsFlowable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Single
Returns a Flowable that merges each item emitted by the source Single with the values in an Iterable corresponding to that item that is generated by a selector.
flattenAsObservable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Maybe
Returns an Observable that maps a success value into an Iterable and emits its items.
flattenAsObservable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Single
Returns an Observable that maps a success value into an Iterable and emits its items.
Flowable<T> - Class in io.reactivex
The Flowable class that implements the Reactive-Streams Pattern and offers factory methods, intermediate operators and the ability to consume reactive dataflows.
Flowable() - Constructor for class io.reactivex.Flowable
 
FlowableAll<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableAll(Flowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableAll
 
FlowableAllSingle<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableAllSingle(Flowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableAllSingle
 
FlowableAmb<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableAmb(Publisher<? extends T>[], Iterable<? extends Publisher<? extends T>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableAmb
 
FlowableAny<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableAny(Flowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableAny
 
FlowableAnySingle<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableAnySingle(Flowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableAnySingle
 
FlowableAutoConnect<T> - Class in io.reactivex.internal.operators.flowable
Wraps a ConnectableFlowable and calls its connect() method once the specified number of Subscribers have subscribed.
FlowableAutoConnect(ConnectableFlowable<? extends T>, int, Consumer<? super Disposable>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableAutoConnect
 
FlowableBlockingSubscribe - Class in io.reactivex.internal.operators.flowable
Utility methods to consume a Publisher in a blocking manner with callbacks or Subscriber.
FlowableBuffer<T,C extends Collection<? super T>> - Class in io.reactivex.internal.operators.flowable
 
FlowableBuffer(Flowable<T>, int, int, Callable<C>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableBuffer
 
FlowableBufferBoundary<T,U extends Collection<? super T>,Open,Close> - Class in io.reactivex.internal.operators.flowable
 
FlowableBufferBoundary(Flowable<T>, Publisher<? extends Open>, Function<? super Open, ? extends Publisher<? extends Close>>, Callable<U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableBufferBoundary
 
FlowableBufferBoundarySupplier<T,U extends Collection<? super T>,B> - Class in io.reactivex.internal.operators.flowable
 
FlowableBufferBoundarySupplier(Flowable<T>, Callable<? extends Publisher<B>>, Callable<U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableBufferBoundarySupplier
 
FlowableBufferExactBoundary<T,U extends Collection<? super T>,B> - Class in io.reactivex.internal.operators.flowable
 
FlowableBufferExactBoundary(Flowable<T>, Publisher<B>, Callable<U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableBufferExactBoundary
 
FlowableBufferTimed<T,U extends Collection<? super T>> - Class in io.reactivex.internal.operators.flowable
 
FlowableBufferTimed(Flowable<T>, long, long, TimeUnit, Scheduler, Callable<U>, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableBufferTimed
 
FlowableCache<T> - Class in io.reactivex.internal.operators.flowable
An observable which auto-connects to another observable, caches the elements from that observable but allows terminating the connection and completing the cache.
FlowableCache(Flowable<T>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableCache
Private constructor because state needs to be shared between the Observable body and the onSubscribe function.
FlowableCollect<T,U> - Class in io.reactivex.internal.operators.flowable
 
FlowableCollect(Flowable<T>, Callable<? extends U>, BiConsumer<? super U, ? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableCollect
 
FlowableCollectSingle<T,U> - Class in io.reactivex.internal.operators.flowable
 
FlowableCollectSingle(Flowable<T>, Callable<? extends U>, BiConsumer<? super U, ? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableCollectSingle
 
FlowableCombineLatest<T,R> - Class in io.reactivex.internal.operators.flowable
Combines the latest values from multiple sources through a function.
FlowableCombineLatest(Publisher<? extends T>[], Function<? super Object[], ? extends R>, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableCombineLatest
 
FlowableCombineLatest(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableCombineLatest
 
FlowableConcatArray<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableConcatArray(Publisher<? extends T>[], boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableConcatArray
 
FlowableConcatMap<T,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableConcatMap(Flowable<T>, Function<? super T, ? extends Publisher<? extends R>>, int, ErrorMode) - Constructor for class io.reactivex.internal.operators.flowable.FlowableConcatMap
 
FlowableConcatMapCompletable<T> - Class in io.reactivex.internal.operators.mixed
Maps the upstream items into CompletableSources and subscribes to them one after the other completes or terminates (in error-delaying mode).
FlowableConcatMapCompletable(Flowable<T>, Function<? super T, ? extends CompletableSource>, ErrorMode, int) - Constructor for class io.reactivex.internal.operators.mixed.FlowableConcatMapCompletable
 
FlowableConcatMapEager<T,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableConcatMapEager(Flowable<T>, Function<? super T, ? extends Publisher<? extends R>>, int, int, ErrorMode) - Constructor for class io.reactivex.internal.operators.flowable.FlowableConcatMapEager
 
FlowableConcatMapEagerPublisher<T,R> - Class in io.reactivex.internal.operators.flowable
ConcatMapEager which works with an arbitrary Publisher source.
FlowableConcatMapEagerPublisher(Publisher<T>, Function<? super T, ? extends Publisher<? extends R>>, int, int, ErrorMode) - Constructor for class io.reactivex.internal.operators.flowable.FlowableConcatMapEagerPublisher
 
FlowableConcatMapMaybe<T,R> - Class in io.reactivex.internal.operators.mixed
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(Flowable<T>, Function<? super T, ? extends MaybeSource<? extends R>>, ErrorMode, int) - Constructor for class io.reactivex.internal.operators.mixed.FlowableConcatMapMaybe
 
FlowableConcatMapPublisher<T,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableConcatMapPublisher(Publisher<T>, Function<? super T, ? extends Publisher<? extends R>>, int, ErrorMode) - Constructor for class io.reactivex.internal.operators.flowable.FlowableConcatMapPublisher
 
FlowableConcatMapSingle<T,R> - Class in io.reactivex.internal.operators.mixed
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(Flowable<T>, Function<? super T, ? extends SingleSource<? extends R>>, ErrorMode, int) - Constructor for class io.reactivex.internal.operators.mixed.FlowableConcatMapSingle
 
FlowableConcatWithCompletable<T> - Class in io.reactivex.internal.operators.flowable
Subscribe to a main Flowable first, then when it completes normally, subscribe to a Completable and terminate when it terminates.
FlowableConcatWithCompletable(Flowable<T>, CompletableSource) - Constructor for class io.reactivex.internal.operators.flowable.FlowableConcatWithCompletable
 
FlowableConcatWithMaybe<T> - Class in io.reactivex.internal.operators.flowable
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(Flowable<T>, MaybeSource<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableConcatWithMaybe
 
FlowableConcatWithSingle<T> - Class in io.reactivex.internal.operators.flowable
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(Flowable<T>, SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableConcatWithSingle
 
FlowableConverter<T,R> - Interface in io.reactivex
Convenience interface and callback used by the Flowable.as(io.reactivex.FlowableConverter<T, ? extends R>) operator to turn a Flowable into another value fluently.
FlowableCount<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableCount(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableCount
 
FlowableCountSingle<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableCountSingle(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableCountSingle
 
FlowableCreate<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableCreate(FlowableOnSubscribe<T>, BackpressureStrategy) - Constructor for class io.reactivex.internal.operators.flowable.FlowableCreate
 
FlowableDebounce<T,U> - Class in io.reactivex.internal.operators.flowable
 
FlowableDebounce(Flowable<T>, Function<? super T, ? extends Publisher<U>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDebounce
 
FlowableDebounceTimed<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableDebounceTimed(Flowable<T>, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDebounceTimed
 
FlowableDefer<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableDefer(Callable<? extends Publisher<? extends T>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDefer
 
FlowableDelay<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableDelay(Flowable<T>, long, TimeUnit, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDelay
 
FlowableDelaySubscriptionOther<T,U> - Class in io.reactivex.internal.operators.flowable
Delays the subscription to the main source until the other observable fires an event or completes.
FlowableDelaySubscriptionOther(Publisher<? extends T>, Publisher<U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDelaySubscriptionOther
 
FlowableDematerialize<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableDematerialize(Flowable<Notification<T>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDematerialize
 
FlowableDetach<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableDetach(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDetach
 
FlowableDistinct<T,K> - Class in io.reactivex.internal.operators.flowable
 
FlowableDistinct(Flowable<T>, Function<? super T, K>, Callable<? extends Collection<? super K>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDistinct
 
FlowableDistinctUntilChanged<T,K> - Class in io.reactivex.internal.operators.flowable
 
FlowableDistinctUntilChanged(Flowable<T>, Function<? super T, K>, BiPredicate<? super K, ? super K>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDistinctUntilChanged
 
FlowableDoAfterNext<T> - Class in io.reactivex.internal.operators.flowable
Calls a consumer after pushing the current item to the downstream.
FlowableDoAfterNext(Flowable<T>, Consumer<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDoAfterNext
 
FlowableDoFinally<T> - Class in io.reactivex.internal.operators.flowable
Execute an action after an onError, onComplete or a cancel event.
FlowableDoFinally(Flowable<T>, Action) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDoFinally
 
FlowableDoOnEach<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableDoOnEach(Flowable<T>, Consumer<? super T>, Consumer<? super Throwable>, Action, Action) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDoOnEach
 
FlowableDoOnLifecycle<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableDoOnLifecycle(Flowable<T>, Consumer<? super Subscription>, LongConsumer, Action) - Constructor for class io.reactivex.internal.operators.flowable.FlowableDoOnLifecycle
 
FlowableElementAt<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableElementAt(Flowable<T>, long, T, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableElementAt
 
FlowableElementAtMaybe<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableElementAtMaybe(Flowable<T>, long) - Constructor for class io.reactivex.internal.operators.flowable.FlowableElementAtMaybe
 
FlowableElementAtSingle<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableElementAtSingle(Flowable<T>, long, T) - Constructor for class io.reactivex.internal.operators.flowable.FlowableElementAtSingle
 
FlowableEmitter<T> - Interface in io.reactivex
Abstraction over a Reactive Streams Subscriber that allows associating a resource with it and exposes the current number of downstream requested amount.
FlowableEmpty - Class in io.reactivex.internal.operators.flowable
A source Flowable that signals an onSubscribe() + onComplete() only.
FlowableError<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableError(Callable<? extends Throwable>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableError
 
FlowableFilter<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableFilter(Flowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFilter
 
FlowableFlatMap<T,U> - Class in io.reactivex.internal.operators.flowable
 
FlowableFlatMap(Flowable<T>, Function<? super T, ? extends Publisher<? extends U>>, boolean, int, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFlatMap
 
FlowableFlatMapCompletable<T> - Class in io.reactivex.internal.operators.flowable
Maps a sequence of values into CompletableSources and awaits their termination.
FlowableFlatMapCompletable(Flowable<T>, Function<? super T, ? extends CompletableSource>, boolean, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFlatMapCompletable
 
FlowableFlatMapCompletableCompletable<T> - Class in io.reactivex.internal.operators.flowable
Maps a sequence of values into CompletableSources and awaits their termination.
FlowableFlatMapCompletableCompletable(Flowable<T>, Function<? super T, ? extends CompletableSource>, boolean, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFlatMapCompletableCompletable
 
FlowableFlatMapMaybe<T,R> - Class in io.reactivex.internal.operators.flowable
Maps upstream values into MaybeSources and merges their signals into one sequence.
FlowableFlatMapMaybe(Flowable<T>, Function<? super T, ? extends MaybeSource<? extends R>>, boolean, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFlatMapMaybe
 
FlowableFlatMapPublisher<T,U> - Class in io.reactivex.internal.operators.flowable
 
FlowableFlatMapPublisher(Publisher<T>, Function<? super T, ? extends Publisher<? extends U>>, boolean, int, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFlatMapPublisher
 
FlowableFlatMapSingle<T,R> - Class in io.reactivex.internal.operators.flowable
Maps upstream values into SingleSources and merges their signals into one sequence.
FlowableFlatMapSingle(Flowable<T>, Function<? super T, ? extends SingleSource<? extends R>>, boolean, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFlatMapSingle
 
FlowableFlattenIterable<T,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableFlattenIterable(Flowable<T>, Function<? super T, ? extends Iterable<? extends R>>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFlattenIterable
 
FlowableFromArray<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableFromArray(T[]) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFromArray
 
FlowableFromCallable<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableFromCallable(Callable<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFromCallable
 
FlowableFromFuture<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableFromFuture(Future<? extends T>, long, TimeUnit) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFromFuture
 
FlowableFromIterable<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableFromIterable(Iterable<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFromIterable
 
FlowableFromObservable<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableFromObservable(Observable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFromObservable
 
FlowableFromPublisher<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableFromPublisher(Publisher<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableFromPublisher
 
FlowableGenerate<T,S> - Class in io.reactivex.internal.operators.flowable
 
FlowableGenerate(Callable<S>, BiFunction<S, Emitter<T>, S>, Consumer<? super S>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableGenerate
 
FlowableGroupBy<T,K,V> - Class in io.reactivex.internal.operators.flowable
 
FlowableGroupBy(Flowable<T>, Function<? super T, ? extends K>, Function<? super T, ? extends V>, int, boolean, Function<? super Consumer<Object>, ? extends Map<K, Object>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableGroupBy
 
FlowableGroupBy.GroupBySubscriber<T,K,V> - Class in io.reactivex.internal.operators.flowable
 
FlowableGroupJoin<TLeft,TRight,TLeftEnd,TRightEnd,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableGroupJoin(Flowable<TLeft>, Publisher<? extends TRight>, Function<? super TLeft, ? extends Publisher<TLeftEnd>>, Function<? super TRight, ? extends Publisher<TRightEnd>>, BiFunction<? super TLeft, ? super Flowable<TRight>, ? extends R>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableGroupJoin
 
FlowableHide<T> - Class in io.reactivex.internal.operators.flowable
Hides the identity of the wrapped Flowable and its Subscription.
FlowableHide(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableHide
 
FlowableIgnoreElements<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableIgnoreElements(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableIgnoreElements
 
FlowableIgnoreElementsCompletable<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableIgnoreElementsCompletable(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableIgnoreElementsCompletable
 
FlowableInternalHelper - Class in io.reactivex.internal.operators.flowable
Helper utility class to support Flowable with inner classes.
FlowableInternalHelper.RequestMax - Enum in io.reactivex.internal.operators.flowable
 
FlowableInterval - Class in io.reactivex.internal.operators.flowable
 
FlowableInterval(long, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.flowable.FlowableInterval
 
FlowableIntervalRange - Class in io.reactivex.internal.operators.flowable
 
FlowableIntervalRange(long, long, long, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.flowable.FlowableIntervalRange
 
FlowableJoin<TLeft,TRight,TLeftEnd,TRightEnd,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableJoin(Flowable<TLeft>, Publisher<? extends TRight>, Function<? super TLeft, ? extends Publisher<TLeftEnd>>, Function<? super TRight, ? extends Publisher<TRightEnd>>, BiFunction<? super TLeft, ? super TRight, ? extends R>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableJoin
 
FlowableJust<T> - Class in io.reactivex.internal.operators.flowable
Represents a constant scalar value.
FlowableJust(T) - Constructor for class io.reactivex.internal.operators.flowable.FlowableJust
 
FlowableLastMaybe<T> - Class in io.reactivex.internal.operators.flowable
Consumes the source Publisher and emits its last item or completes.
FlowableLastMaybe(Publisher<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableLastMaybe
 
FlowableLastSingle<T> - Class in io.reactivex.internal.operators.flowable
Consumes the source Publisher and emits its last item or the defaultItem if empty.
FlowableLastSingle(Publisher<T>, T) - Constructor for class io.reactivex.internal.operators.flowable.FlowableLastSingle
 
FlowableLift<R,T> - Class in io.reactivex.internal.operators.flowable
Allows lifting operators into a chain of Publishers.
FlowableLift(Flowable<T>, FlowableOperator<? extends R, ? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableLift
 
FlowableLimit<T> - Class in io.reactivex.internal.operators.flowable
Limits both the total request amount and items received from the upstream.
FlowableLimit(Flowable<T>, long) - Constructor for class io.reactivex.internal.operators.flowable.FlowableLimit
 
FlowableMap<T,U> - Class in io.reactivex.internal.operators.flowable
 
FlowableMap(Flowable<T>, Function<? super T, ? extends U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableMap
 
FlowableMapNotification<T,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableMapNotification(Flowable<T>, Function<? super T, ? extends R>, Function<? super Throwable, ? extends R>, Callable<? extends R>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableMapNotification
 
FlowableMapPublisher<T,U> - Class in io.reactivex.internal.operators.flowable
Map working with an arbitrary Publisher source.
FlowableMapPublisher(Publisher<T>, Function<? super T, ? extends U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableMapPublisher
 
FlowableMaterialize<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableMaterialize(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableMaterialize
 
FlowableMergeWithCompletable<T> - Class in io.reactivex.internal.operators.flowable
Merges a Flowable and a Completable by emitting the items of the Flowable and waiting until both the Flowable and Completable complete normally.
FlowableMergeWithCompletable(Flowable<T>, CompletableSource) - Constructor for class io.reactivex.internal.operators.flowable.FlowableMergeWithCompletable
 
FlowableMergeWithMaybe<T> - Class in io.reactivex.internal.operators.flowable
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(Flowable<T>, MaybeSource<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableMergeWithMaybe
 
FlowableMergeWithSingle<T> - Class in io.reactivex.internal.operators.flowable
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(Flowable<T>, SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableMergeWithSingle
 
FlowableNever - Class in io.reactivex.internal.operators.flowable
 
FlowableObserveOn<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableObserveOn(Flowable<T>, Scheduler, boolean, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableObserveOn
 
FlowableOnBackpressureBuffer<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableOnBackpressureBuffer(Flowable<T>, int, boolean, boolean, Action) - Constructor for class io.reactivex.internal.operators.flowable.FlowableOnBackpressureBuffer
 
FlowableOnBackpressureBufferStrategy<T> - Class in io.reactivex.internal.operators.flowable
Handle backpressure with a bounded buffer and custom strategy.
FlowableOnBackpressureBufferStrategy(Flowable<T>, long, Action, BackpressureOverflowStrategy) - Constructor for class io.reactivex.internal.operators.flowable.FlowableOnBackpressureBufferStrategy
 
FlowableOnBackpressureDrop<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableOnBackpressureDrop(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableOnBackpressureDrop
 
FlowableOnBackpressureDrop(Flowable<T>, Consumer<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableOnBackpressureDrop
 
FlowableOnBackpressureError<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableOnBackpressureError(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableOnBackpressureError
 
FlowableOnBackpressureLatest<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableOnBackpressureLatest(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableOnBackpressureLatest
 
FlowableOnErrorNext<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableOnErrorNext(Flowable<T>, Function<? super Throwable, ? extends Publisher<? extends T>>, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableOnErrorNext
 
FlowableOnErrorReturn<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableOnErrorReturn(Flowable<T>, Function<? super Throwable, ? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableOnErrorReturn
 
FlowableOnSubscribe<T> - Interface in io.reactivex
A functional interface that has a subscribe() method that receives an instance of a FlowableEmitter instance that allows pushing events in a backpressure-safe and cancellation-safe manner.
FlowableOperator<Downstream,Upstream> - Interface in io.reactivex
Interface to map/wrap a downstream subscriber to an upstream subscriber.
FlowableProcessor<T> - Class in io.reactivex.processors
Represents a Subscriber and a Flowable (Publisher) at the same time, allowing multicasting events from a single source to multiple child Subscribers.
FlowableProcessor() - Constructor for class io.reactivex.processors.FlowableProcessor
 
FlowablePublish<T> - Class in io.reactivex.internal.operators.flowable
A connectable observable which shares an underlying source and dispatches source values to subscribers in a backpressure-aware manner.
FlowablePublishMulticast<T,R> - Class in io.reactivex.internal.operators.flowable
Multicasts a Flowable over a selector function.
FlowablePublishMulticast(Flowable<T>, Function<? super Flowable<T>, ? extends Publisher<? extends R>>, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowablePublishMulticast
 
FlowableRange - Class in io.reactivex.internal.operators.flowable
Emits a range of integer values.
FlowableRange(int, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRange
 
FlowableRangeLong - Class in io.reactivex.internal.operators.flowable
Emits a range of long values.
FlowableRangeLong(long, long) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRangeLong
 
FlowableReduce<T> - Class in io.reactivex.internal.operators.flowable
Reduces a sequence via a function into a single value or signals NoSuchElementException for an empty source.
FlowableReduce(Flowable<T>, BiFunction<T, T, T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableReduce
 
FlowableReduceMaybe<T> - Class in io.reactivex.internal.operators.flowable
Reduce a Flowable into a single value exposed as Single or signal NoSuchElementException.
FlowableReduceMaybe(Flowable<T>, BiFunction<T, T, T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableReduceMaybe
 
FlowableReduceSeedSingle<T,R> - Class in io.reactivex.internal.operators.flowable
Reduce a sequence of values, starting from a seed value and by using an accumulator function and return the last accumulated value.
FlowableReduceSeedSingle(Publisher<T>, R, BiFunction<R, ? super T, R>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableReduceSeedSingle
 
FlowableReduceWithSingle<T,R> - Class in io.reactivex.internal.operators.flowable
Reduce a sequence of values, starting from a generated seed value and by using an accumulator function and return the last accumulated value.
FlowableReduceWithSingle(Publisher<T>, Callable<R>, BiFunction<R, ? super T, R>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableReduceWithSingle
 
FlowableRefCount<T> - Class in io.reactivex.internal.operators.flowable
Returns an observable sequence that stays connected to the source as long as there is at least one subscription to the observable sequence.
FlowableRefCount(ConnectableFlowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRefCount
 
FlowableRefCount(ConnectableFlowable<T>, int, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRefCount
 
FlowableRepeat<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableRepeat(Flowable<T>, long) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRepeat
 
FlowableRepeatUntil<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableRepeatUntil(Flowable<T>, BooleanSupplier) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRepeatUntil
 
FlowableRepeatWhen<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableRepeatWhen(Flowable<T>, Function<? super Flowable<Object>, ? extends Publisher<?>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRepeatWhen
 
FlowableReplay<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableRetryBiPredicate<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableRetryBiPredicate(Flowable<T>, BiPredicate<? super Integer, ? super Throwable>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRetryBiPredicate
 
FlowableRetryPredicate<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableRetryPredicate(Flowable<T>, long, Predicate<? super Throwable>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRetryPredicate
 
FlowableRetryWhen<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableRetryWhen(Flowable<T>, Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableRetryWhen
 
FlowableSamplePublisher<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSamplePublisher(Publisher<T>, Publisher<?>, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSamplePublisher
 
FlowableSampleTimed<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSampleTimed(Flowable<T>, long, TimeUnit, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSampleTimed
 
FlowableScalarXMap - Class in io.reactivex.internal.operators.flowable
Utility classes to work with scalar-sourced XMap operators (where X == { flat, concat, switch }).
FlowableScan<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableScan(Flowable<T>, BiFunction<T, T, T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableScan
 
FlowableScanSeed<T,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableScanSeed(Flowable<T>, Callable<R>, BiFunction<R, ? super T, R>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableScanSeed
 
FlowableSequenceEqual<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSequenceEqual(Publisher<? extends T>, Publisher<? extends T>, BiPredicate<? super T, ? super T>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSequenceEqual
 
FlowableSequenceEqualSingle<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSequenceEqualSingle(Publisher<? extends T>, Publisher<? extends T>, BiPredicate<? super T, ? super T>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSequenceEqualSingle
 
FlowableSerialized<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSerialized(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSerialized
 
FlowableSingle<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSingle(Flowable<T>, T, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSingle
 
FlowableSingleMaybe<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSingleMaybe(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSingleMaybe
 
FlowableSingleSingle<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSingleSingle(Flowable<T>, T) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSingleSingle
 
FlowableSkip<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSkip(Flowable<T>, long) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSkip
 
FlowableSkipLast<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSkipLast(Flowable<T>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSkipLast
 
FlowableSkipLastTimed<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSkipLastTimed(Flowable<T>, long, TimeUnit, Scheduler, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSkipLastTimed
 
FlowableSkipUntil<T,U> - Class in io.reactivex.internal.operators.flowable
 
FlowableSkipUntil(Flowable<T>, Publisher<U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSkipUntil
 
FlowableSkipWhile<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSkipWhile(Flowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSkipWhile
 
FlowableSubscribeOn<T> - Class in io.reactivex.internal.operators.flowable
Subscribes to the source Flowable on the specified Scheduler and makes sure downstream requests are scheduled there as well.
FlowableSubscribeOn(Flowable<T>, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSubscribeOn
 
FlowableSubscriber<T> - Interface in io.reactivex
Represents a Reactive-Streams inspired Subscriber that is RxJava 2 only and weakens rules §1.3 and §3.9 of the specification for gaining performance.
FlowableSwitchIfEmpty<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableSwitchIfEmpty(Flowable<T>, Publisher<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSwitchIfEmpty
 
FlowableSwitchMap<T,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableSwitchMap(Flowable<T>, Function<? super T, ? extends Publisher<? extends R>>, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableSwitchMap
 
FlowableSwitchMapCompletable<T> - Class in io.reactivex.internal.operators.mixed
Maps the upstream values into CompletableSources, subscribes to the newer one while disposing the subscription to the previous CompletableSource, thus keeping at most one active CompletableSource running.
FlowableSwitchMapCompletable(Flowable<T>, Function<? super T, ? extends CompletableSource>, boolean) - Constructor for class io.reactivex.internal.operators.mixed.FlowableSwitchMapCompletable
 
FlowableSwitchMapMaybe<T,R> - Class in io.reactivex.internal.operators.mixed
Maps the upstream items into MaybeSources 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(Flowable<T>, Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Constructor for class io.reactivex.internal.operators.mixed.FlowableSwitchMapMaybe
 
FlowableSwitchMapSingle<T,R> - Class in io.reactivex.internal.operators.mixed
Maps the upstream items into SingleSources 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(Flowable<T>, Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Constructor for class io.reactivex.internal.operators.mixed.FlowableSwitchMapSingle
 
FlowableTake<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableTake(Flowable<T>, long) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTake
 
FlowableTakeLast<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableTakeLast(Flowable<T>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTakeLast
 
FlowableTakeLastOne<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableTakeLastOne(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTakeLastOne
 
FlowableTakeLastTimed<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableTakeLastTimed(Flowable<T>, long, long, TimeUnit, Scheduler, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTakeLastTimed
 
FlowableTakePublisher<T> - Class in io.reactivex.internal.operators.flowable
Take with a generic Publisher source.
FlowableTakePublisher(Publisher<T>, long) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTakePublisher
 
FlowableTakeUntil<T,U> - Class in io.reactivex.internal.operators.flowable
 
FlowableTakeUntil(Flowable<T>, Publisher<? extends U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTakeUntil
 
FlowableTakeUntilPredicate<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableTakeUntilPredicate(Flowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTakeUntilPredicate
 
FlowableTakeWhile<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableTakeWhile(Flowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTakeWhile
 
FlowableThrottleFirstTimed<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableThrottleFirstTimed(Flowable<T>, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.flowable.FlowableThrottleFirstTimed
 
FlowableThrottleLatest<T> - Class in io.reactivex.internal.operators.flowable
Emits the next or latest item when the given time elapses.
FlowableThrottleLatest(Flowable<T>, long, TimeUnit, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableThrottleLatest
 
FlowableTimeInterval<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableTimeInterval(Flowable<T>, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTimeInterval
 
FlowableTimeout<T,U,V> - Class in io.reactivex.internal.operators.flowable
 
FlowableTimeout(Flowable<T>, Publisher<U>, Function<? super T, ? extends Publisher<V>>, Publisher<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTimeout
 
FlowableTimeoutTimed<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableTimeoutTimed(Flowable<T>, long, TimeUnit, Scheduler, Publisher<? extends T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTimeoutTimed
 
FlowableTimer - Class in io.reactivex.internal.operators.flowable
 
FlowableTimer(long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.flowable.FlowableTimer
 
FlowableToList<T,U extends Collection<? super T>> - Class in io.reactivex.internal.operators.flowable
 
FlowableToList(Flowable<T>, Callable<U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableToList
 
FlowableToListSingle<T,U extends Collection<? super T>> - Class in io.reactivex.internal.operators.flowable
 
FlowableToListSingle(Flowable<T>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableToListSingle
 
FlowableToListSingle(Flowable<T>, Callable<U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableToListSingle
 
FlowableTransformer<Upstream,Downstream> - Interface in io.reactivex
Interface to compose Flowables.
FlowableUnsubscribeOn<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableUnsubscribeOn(Flowable<T>, Scheduler) - Constructor for class io.reactivex.internal.operators.flowable.FlowableUnsubscribeOn
 
FlowableUsing<T,D> - Class in io.reactivex.internal.operators.flowable
 
FlowableUsing(Callable<? extends D>, Function<? super D, ? extends Publisher<? extends T>>, Consumer<? super D>, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableUsing
 
FlowableWindow<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableWindow(Flowable<T>, long, long, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableWindow
 
FlowableWindowBoundary<T,B> - Class in io.reactivex.internal.operators.flowable
 
FlowableWindowBoundary(Flowable<T>, Publisher<B>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableWindowBoundary
 
FlowableWindowBoundarySelector<T,B,V> - Class in io.reactivex.internal.operators.flowable
 
FlowableWindowBoundarySelector(Flowable<T>, Publisher<B>, Function<? super B, ? extends Publisher<V>>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableWindowBoundarySelector
 
FlowableWindowBoundarySupplier<T,B> - Class in io.reactivex.internal.operators.flowable
 
FlowableWindowBoundarySupplier(Flowable<T>, Callable<? extends Publisher<B>>, int) - Constructor for class io.reactivex.internal.operators.flowable.FlowableWindowBoundarySupplier
 
FlowableWindowTimed<T> - Class in io.reactivex.internal.operators.flowable
 
FlowableWindowTimed(Flowable<T>, long, long, TimeUnit, Scheduler, long, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableWindowTimed
 
FlowableWithLatestFrom<T,U,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableWithLatestFrom(Flowable<T>, BiFunction<? super T, ? super U, ? extends R>, Publisher<? extends U>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableWithLatestFrom
 
FlowableWithLatestFromMany<T,R> - Class in io.reactivex.internal.operators.flowable
Combines a main sequence of values with the latest from multiple other sequences via a selector function.
FlowableWithLatestFromMany(Flowable<T>, Publisher<?>[], Function<? super Object[], R>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableWithLatestFromMany
 
FlowableWithLatestFromMany(Flowable<T>, Iterable<? extends Publisher<?>>, Function<? super Object[], R>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableWithLatestFromMany
 
FlowableZip<T,R> - Class in io.reactivex.internal.operators.flowable
 
FlowableZip(Publisher<? extends T>[], Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>, int, boolean) - Constructor for class io.reactivex.internal.operators.flowable.FlowableZip
 
FlowableZipIterable<T,U,V> - Class in io.reactivex.internal.operators.flowable
 
FlowableZipIterable(Flowable<T>, Iterable<U>, BiFunction<? super T, ? super U, ? extends V>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableZipIterable
 
forEach(Consumer<? super T>) - Method in class io.reactivex.Flowable
Subscribes to the Publisher and receives notifications for each element.
forEach(Consumer<? super T>) - Method in class io.reactivex.Observable
Subscribes to the ObservableSource and receives notifications for each element.
forEachWhile(Predicate<? super T>) - Method in class io.reactivex.Flowable
Subscribes to the Publisher and receives notifications for each element until the onNext Predicate returns false.
forEachWhile(Predicate<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Flowable
Subscribes to the Publisher and receives notifications for each element and error events until the onNext Predicate returns false.
forEachWhile(Predicate<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.Flowable
Subscribes to the Publisher and receives notifications for each element and the terminal events until the onNext Predicate returns false.
forEachWhile(AppendOnlyLinkedArrayList.NonThrowingPredicate<? super T>) - Method in class io.reactivex.internal.util.AppendOnlyLinkedArrayList
Loops over all elements of the array until a null element is encountered or the given predicate returns true.
forEachWhile(S, BiPredicate<? super S, ? super T>) - Method in class io.reactivex.internal.util.AppendOnlyLinkedArrayList
Loops over all elements of the array until a null element is encountered or the given predicate returns true.
forEachWhile(Predicate<? super T>) - Method in class io.reactivex.Observable
Subscribes to the ObservableSource and receives notifications for each element until the onNext Predicate returns false.
forEachWhile(Predicate<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Observable
Subscribes to the ObservableSource and receives notifications for each element and error events until the onNext Predicate returns false.
forEachWhile(Predicate<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.Observable
Subscribes to the ObservableSource and receives notifications for each element and the terminal events until the onNext Predicate returns false.
ForEachWhileObserver<T> - Class in io.reactivex.internal.observers
 
ForEachWhileObserver(Predicate<? super T>, Consumer<? super Throwable>, Action) - Constructor for class io.reactivex.internal.observers.ForEachWhileObserver
 
ForEachWhileSubscriber<T> - Class in io.reactivex.internal.subscribers
 
ForEachWhileSubscriber(Predicate<? super T>, Consumer<? super Throwable>, Action) - Constructor for class io.reactivex.internal.subscribers.ForEachWhileSubscriber
 
from(Observable<T>) - Static method in class io.reactivex.internal.operators.observable.ObservableCache
Creates a cached Observable with a default capacity hint of 16.
from(Observable<T>, int) - Static method in class io.reactivex.internal.operators.observable.ObservableCache
Creates a cached Observable with the given capacity hint.
from(Publisher<? extends T>) - Static method in class io.reactivex.parallel.ParallelFlowable
Take a Publisher and prepare to consume it on multiple 'rails' (number of CPUs) in a round-robin fashion.
from(Publisher<? extends T>, int) - Static method in class io.reactivex.parallel.ParallelFlowable
Take a Publisher and prepare to consume it on parallelism number of 'rails' in a round-robin fashion.
from(Publisher<? extends T>, int, int) - Static method in class io.reactivex.parallel.ParallelFlowable
Take a Publisher and prepare to consume it on parallelism number of 'rails' , possibly ordered and round-robin fashion and use custom prefetch amount and queue for dealing with the source Publisher's values.
from(Executor) - Static method in class io.reactivex.schedulers.Schedulers
Wraps an Executor into a new Scheduler instance and delegates schedule() calls to it.
fromAction(Action) - Static method in class io.reactivex.Completable
Returns a Completable instance that runs the given Action for each subscriber and emits either an unchecked exception or simply completes.
fromAction(Action) - Static method in class io.reactivex.disposables.Disposables
Construct a Disposable by wrapping a Action that is executed exactly once when the Disposable is disposed.
fromAction(Action) - Static method in class io.reactivex.Maybe
Returns a Maybe instance that runs the given Action for each subscriber and emits either its exception or simply completes.
fromArray(T...) - Static method in class io.reactivex.Flowable
Converts an Array into a Publisher that emits the items in the Array.
fromArray(T...) - Static method in class io.reactivex.Observable
Converts an Array into an ObservableSource that emits the items in the Array.
fromArray(Publisher<T>...) - Static method in class io.reactivex.parallel.ParallelFlowable
Wraps multiple Publishers into a ParallelFlowable which runs them in parallel and unordered.
fromCallable(Callable<?>) - Static method in class io.reactivex.Completable
Returns a Completable which when subscribed, executes the callable function, ignores its normal result and emits onError or onComplete only.
fromCallable(Callable<? extends T>) - Static method in class io.reactivex.Flowable
Returns a Flowable that, when a Subscriber subscribes to it, invokes a function you specify and then emits the value returned from that function.
fromCallable(Callable<? extends T>) - Static method in class io.reactivex.Maybe
Returns a Maybe that invokes the given Callable for each individual MaybeObserver that subscribes and emits the resulting non-null item via onSuccess while considering a null result from the Callable as indication for valueless completion via onComplete.
fromCallable(Callable<? extends T>) - Static method in class io.reactivex.Observable
Returns an Observable that, when an observer subscribes to it, invokes a function you specify and then emits the value returned from that function.
fromCallable(Callable<? extends T>) - Static method in class io.reactivex.Single
Returns a Single that invokes passed function and emits its result for each new SingleObserver that subscribes.
fromCompletable(CompletableSource) - Static method in class io.reactivex.Maybe
Wraps a CompletableSource into a Maybe.
fromFuture(Future<?>) - Static method in class io.reactivex.Completable
Returns a Completable instance that reacts to the termination of the given Future in a blocking fashion.
fromFuture(Future<?>) - Static method in class io.reactivex.disposables.Disposables
Construct a Disposable by wrapping a Future that is cancelled exactly once when the Disposable is disposed.
fromFuture(Future<?>, boolean) - Static method in class io.reactivex.disposables.Disposables
Construct a Disposable by wrapping a Future that is cancelled exactly once when the Disposable is disposed.
fromFuture(Future<? extends T>) - Static method in class io.reactivex.Flowable
Converts a Future into a Publisher.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class io.reactivex.Flowable
Converts a Future into a Publisher, with a timeout on the Future.
fromFuture(Future<? extends T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Flowable
Converts a Future into a Publisher, with a timeout on the Future.
fromFuture(Future<? extends T>, Scheduler) - Static method in class io.reactivex.Flowable
Converts a Future, operating on a specified Scheduler, into a Publisher.
fromFuture(Future<? extends T>) - Static method in class io.reactivex.Maybe
Converts a Future into a Maybe, treating a null result as an indication of emptiness.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class io.reactivex.Maybe
Converts a Future into a Maybe, with a timeout on the Future.
fromFuture(Future<? extends T>) - Static method in class io.reactivex.Observable
Converts a Future into an ObservableSource.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class io.reactivex.Observable
Converts a Future into an ObservableSource, with a timeout on the Future.
fromFuture(Future<? extends T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Observable
Converts a Future into an ObservableSource, with a timeout on the Future.
fromFuture(Future<? extends T>, Scheduler) - Static method in class io.reactivex.Observable
Converts a Future, operating on a specified Scheduler, into an ObservableSource.
fromFuture(Future<? extends T>) - Static method in class io.reactivex.Single
Converts a Future into a Single.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class io.reactivex.Single
Converts a Future into a Single, with a timeout on the Future.
fromFuture(Future<? extends T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Single
Converts a Future into a Single, with a timeout on the Future.
fromFuture(Future<? extends T>, Scheduler) - Static method in class io.reactivex.Single
Converts a Future, operating on a specified Scheduler, into a Single.
fromIterable(Iterable<? extends T>) - Static method in class io.reactivex.Flowable
Converts an Iterable sequence into a Publisher that emits the items in the sequence.
fromIterable(Iterable<? extends T>) - Static method in class io.reactivex.Observable
Converts an Iterable sequence into an ObservableSource that emits the items in the sequence.
fromObservable(ObservableSource<T>) - Static method in class io.reactivex.Completable
Returns a Completable instance that subscribes to the given Observable, ignores all values and emits only the terminal event.
fromObservable(ObservableSource<? extends T>) - Static method in class io.reactivex.Single
Wraps a specific ObservableSource into a Single and signals its single element or error.
fromPublisher(Publisher<T>) - Static method in class io.reactivex.Completable
Returns a Completable instance that subscribes to the given publisher, ignores all values and emits only the terminal event.
fromPublisher(Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Converts an arbitrary Reactive-Streams Publisher into a Flowable if not already a Flowable.
fromPublisher(Publisher<? extends T>) - Static method in class io.reactivex.Observable
Converts an arbitrary Reactive-Streams Publisher into an Observable.
fromPublisher(Publisher<? extends T>) - Static method in class io.reactivex.Single
Wraps a specific Publisher into a Single and signals its single element or error.
fromRunnable(Runnable) - Static method in class io.reactivex.Completable
Returns a Completable instance that runs the given Runnable for each subscriber and emits either its exception or simply completes.
fromRunnable(Runnable) - Static method in class io.reactivex.disposables.Disposables
Construct a Disposable by wrapping a Runnable that is executed exactly once when the Disposable is disposed.
fromRunnable(Runnable) - Static method in class io.reactivex.Maybe
Returns a Maybe instance that runs the given Action for each subscriber and emits either its exception or simply completes.
fromSingle(SingleSource<T>) - Static method in class io.reactivex.Completable
Returns a Completable instance that when subscribed to, subscribes to the Single instance and emits a completion event if the single emits onSuccess or forwards any onError events.
fromSingle(SingleSource<T>) - Static method in class io.reactivex.Maybe
Wraps a SingleSource into a Maybe.
fromSubscription(Subscription) - Static method in class io.reactivex.disposables.Disposables
Construct a Disposable by wrapping a Subscription that is cancelled exactly once when the Disposable is disposed.
Function<T,R> - Interface in io.reactivex.functions
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> - Interface in io.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function4<T1,T2,T3,T4,R> - Interface in io.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function5<T1,T2,T3,T4,T5,R> - Interface in io.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function6<T1,T2,T3,T4,T5,T6,R> - Interface in io.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in io.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in io.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in io.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Functions - Class in io.reactivex.internal.functions
Utility methods to convert the BiFunction, Function3..Function9 instances to Function of Object array.
Functions.BoundedConsumer - Class in io.reactivex.internal.functions
 
FuseToFlowable<T> - Interface in io.reactivex.internal.fuseable
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:
fuseToFlowable() - Method in interface io.reactivex.internal.fuseable.FuseToFlowable
Returns a (direct) Flowable for the operator.
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableAllSingle
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableAnySingle
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableCollectSingle
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableCountSingle
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableElementAtMaybe
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableElementAtSingle
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableFlatMapCompletableCompletable
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableIgnoreElementsCompletable
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableReduceMaybe
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableSequenceEqualSingle
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableSingleMaybe
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableSingleSingle
 
fuseToFlowable() - Method in class io.reactivex.internal.operators.flowable.FlowableToListSingle
 
FuseToMaybe<T> - Interface in io.reactivex.internal.fuseable
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:
fuseToMaybe() - Method in interface io.reactivex.internal.fuseable.FuseToMaybe
Returns a (direct) Maybe for the operator.
fuseToMaybe() - Method in class io.reactivex.internal.operators.maybe.MaybeIgnoreElementCompletable
 
fuseToMaybe() - Method in class io.reactivex.internal.operators.maybe.MaybeIsEmptySingle
 
FuseToObservable<T> - Interface in io.reactivex.internal.fuseable
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:
fuseToObservable() - Method in interface io.reactivex.internal.fuseable.FuseToObservable
Returns a (direct) Observable for the operator.
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableAllSingle
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableAnySingle
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableCollectSingle
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableCountSingle
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableElementAtMaybe
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableElementAtSingle
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableFlatMapCompletableCompletable
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableIgnoreElementsCompletable
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableSequenceEqualSingle
 
fuseToObservable() - Method in class io.reactivex.internal.operators.observable.ObservableToListSingle
 
fusionMode() - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
futureAction(Future<?>) - Static method in class io.reactivex.internal.functions.Functions
Wraps the blocking get call of the Future into an Action.
FutureObserver<T> - Class in io.reactivex.internal.observers
An Observer + Future that expects exactly one upstream value and provides it via the (blocking) Future API.
FutureObserver() - Constructor for class io.reactivex.internal.observers.FutureObserver
 
FutureSingleObserver<T> - Class in io.reactivex.internal.observers
An Observer + Future that expects exactly one upstream value and provides it via the (blocking) Future API.
FutureSingleObserver() - Constructor for class io.reactivex.internal.observers.FutureSingleObserver
 
FutureSubscriber<T> - Class in io.reactivex.internal.subscribers
A Subscriber + Future that expects exactly one upstream value and provides it via the (blocking) Future API.
FutureSubscriber() - Constructor for class io.reactivex.internal.subscribers.FutureSubscriber
 

G

generate(Consumer<Emitter<T>>) - Static method in class io.reactivex.Flowable
Returns a cold, synchronous, stateless and backpressure-aware generator of values.
generate(Callable<S>, BiConsumer<S, Emitter<T>>) - Static method in class io.reactivex.Flowable
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
generate(Callable<S>, BiConsumer<S, Emitter<T>>, Consumer<? super S>) - Static method in class io.reactivex.Flowable
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
generate(Callable<S>, BiFunction<S, Emitter<T>, S>) - Static method in class io.reactivex.Flowable
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
generate(Callable<S>, BiFunction<S, Emitter<T>, S>, Consumer<? super S>) - Static method in class io.reactivex.Flowable
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
generate(Consumer<Emitter<T>>) - Static method in class io.reactivex.Observable
Returns a cold, synchronous and stateless generator of values.
generate(Callable<S>, BiConsumer<S, Emitter<T>>) - Static method in class io.reactivex.Observable
Returns a cold, synchronous and stateful generator of values.
generate(Callable<S>, BiConsumer<S, Emitter<T>>, Consumer<? super S>) - Static method in class io.reactivex.Observable
Returns a cold, synchronous and stateful generator of values.
generate(Callable<S>, BiFunction<S, Emitter<T>, S>) - Static method in class io.reactivex.Observable
Returns a cold, synchronous and stateful generator of values.
generate(Callable<S>, BiFunction<S, Emitter<T>, S>, Consumer<? super S>) - Static method in class io.reactivex.Observable
Returns a cold, synchronous and stateful generator of values.
get() - Method in class io.reactivex.disposables.SerialDisposable
Returns the currently contained Disposable or null if this container is empty.
get() - Method in class io.reactivex.internal.observers.FutureObserver
 
get(long, TimeUnit) - Method in class io.reactivex.internal.observers.FutureObserver
 
get() - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
get(long, TimeUnit) - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
get() - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
get(long, TimeUnit) - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
get(int) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
getAsBoolean() - Method in interface io.reactivex.functions.BooleanSupplier
Returns a boolean value.
getCause() - Method in exception io.reactivex.exceptions.CompositeException
 
getComputationSchedulerHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getDisposable(Object) - Static method in enum io.reactivex.internal.util.NotificationLite
 
getError(Object) - Static method in enum io.reactivex.internal.util.NotificationLite
Extracts the Throwable from the notification object.
getError() - Method in class io.reactivex.Notification
Returns the container Throwable error if this notification is an onError signal, null otherwise.
getErrorHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the a hook consumer.
getEvents() - Method in class io.reactivex.observers.BaseTestConsumer
Returns a list of 3 other lists: the first inner list contains the plain values received; the second list contains the potential errors and the final list contains the potential completions as Notifications.
getExceptions() - Method in exception io.reactivex.exceptions.CompositeException
Retrieves the list of exceptions that make up the CompositeException.
getInitComputationSchedulerHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getInitIoSchedulerHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getInitNewThreadSchedulerHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getInitSingleSchedulerHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getIoSchedulerHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getKey() - Method in class io.reactivex.flowables.GroupedFlowable
Returns the key that identifies the group of items emitted by this GroupedFlowable.
getKey() - Method in class io.reactivex.observables.GroupedObservable
Returns the key that identifies the group of items emitted by this GroupedObservable.
getMessage() - Method in exception io.reactivex.exceptions.CompositeException
 
getNewThreadSchedulerHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnBeforeBlocking() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current blocking handler or null if no custom handler is set.
getOnCompletableAssembly() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnCompletableSubscribe() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnConnectableFlowableAssembly() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnConnectableObservableAssembly() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnFlowableAssembly() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnFlowableSubscribe() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnMaybeAssembly() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnMaybeSubscribe() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnObservableAssembly() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnObservableSubscribe() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnParallelAssembly() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnSingleAssembly() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getOnSingleSubscribe() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getScheduleHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getSingleSchedulerHandler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns the current hook function.
getSubscription(Object) - Static method in enum io.reactivex.internal.util.NotificationLite
Extracts the Subscription from the notification object.
getThrowable() - Method in class io.reactivex.processors.AsyncProcessor
 
getThrowable() - Method in class io.reactivex.processors.BehaviorProcessor
 
getThrowable() - Method in class io.reactivex.processors.FlowableProcessor
Returns the error that caused the FlowableProcessor to terminate or null if the FlowableProcessor hasn't terminated yet.
getThrowable() - Method in class io.reactivex.processors.MulticastProcessor
 
getThrowable() - Method in class io.reactivex.processors.PublishProcessor
 
getThrowable() - Method in class io.reactivex.processors.ReplayProcessor
 
getThrowable() - Method in class io.reactivex.processors.UnicastProcessor
 
getThrowable() - Method in class io.reactivex.subjects.AsyncSubject
 
getThrowable() - Method in class io.reactivex.subjects.BehaviorSubject
 
getThrowable() - Method in class io.reactivex.subjects.CompletableSubject
Returns the terminal error if this CompletableSubject has been terminated with an error, null otherwise.
getThrowable() - Method in class io.reactivex.subjects.MaybeSubject
Returns the terminal error if this MaybeSubject has been terminated with an error, null otherwise.
getThrowable() - Method in class io.reactivex.subjects.PublishSubject
 
getThrowable() - Method in class io.reactivex.subjects.ReplaySubject
 
getThrowable() - Method in class io.reactivex.subjects.SingleSubject
Returns the terminal error if this SingleSubject has been terminated with an error, null otherwise.
getThrowable() - Method in class io.reactivex.subjects.Subject
Returns the error that caused the Subject to terminate or null if the Subject hasn't terminated yet.
getThrowable() - Method in class io.reactivex.subjects.UnicastSubject
 
getValue(Object) - Static method in enum io.reactivex.internal.util.NotificationLite
Extracts the value from the notification object.
getValue() - Method in class io.reactivex.Notification
Returns the contained value if this notification is an onNext signal, null otherwise.
getValue() - Method in class io.reactivex.processors.AsyncProcessor
Returns a single value this processor currently has or null if no such value exists.
getValue() - Method in class io.reactivex.processors.BehaviorProcessor
Returns a single value the BehaviorProcessor currently has or null if no such value exists.
getValue() - Method in class io.reactivex.processors.ReplayProcessor
Returns the latest value this processor has or null if no such value exists.
getValue() - Method in class io.reactivex.subjects.AsyncSubject
Returns a single value the Subject currently has or null if no such value exists.
getValue() - Method in class io.reactivex.subjects.BehaviorSubject
Returns a single value the Subject currently has or null if no such value exists.
getValue() - Method in class io.reactivex.subjects.MaybeSubject
Returns the success value if this MaybeSubject was terminated with a success value.
getValue() - Method in class io.reactivex.subjects.ReplaySubject
Returns a single value the Subject currently has or null if no such value exists.
getValue() - Method in class io.reactivex.subjects.SingleSubject
Returns the success value if this SingleSubject was terminated with a success value.
getValues() - Method in class io.reactivex.processors.AsyncProcessor
Deprecated.
in 2.1.14; put the result of AsyncProcessor.getValue() into an array manually, will be removed in 3.x
getValues(T[]) - Method in class io.reactivex.processors.AsyncProcessor
Deprecated.
in 2.1.14; put the result of AsyncProcessor.getValue() into an array manually, will be removed in 3.x
getValues() - Method in class io.reactivex.processors.BehaviorProcessor
Deprecated.
in 2.1.14; put the result of BehaviorProcessor.getValue() into an array manually, will be removed in 3.x
getValues(T[]) - Method in class io.reactivex.processors.BehaviorProcessor
Deprecated.
in 2.1.14; put the result of BehaviorProcessor.getValue() into an array manually, will be removed in 3.x
getValues() - Method in class io.reactivex.processors.ReplayProcessor
Returns an Object array containing snapshot all values of this processor.
getValues(T[]) - Method in class io.reactivex.processors.ReplayProcessor
Returns a typed array containing a snapshot of all values of this processor.
getValues() - Method in class io.reactivex.subjects.AsyncSubject
Deprecated.
in 2.1.14; put the result of AsyncSubject.getValue() into an array manually, will be removed in 3.x
getValues(T[]) - Method in class io.reactivex.subjects.AsyncSubject
Deprecated.
in 2.1.14; put the result of AsyncSubject.getValue() into an array manually, will be removed in 3.x
getValues() - Method in class io.reactivex.subjects.BehaviorSubject
Deprecated.
in 2.1.14; put the result of BehaviorSubject.getValue() into an array manually, will be removed in 3.x
getValues(T[]) - Method in class io.reactivex.subjects.BehaviorSubject
Deprecated.
in 2.1.14; put the result of BehaviorSubject.getValue() into an array manually, will be removed in 3.x
getValues() - Method in class io.reactivex.subjects.ReplaySubject
Returns an Object array containing snapshot all values of the Subject.
getValues(T[]) - Method in class io.reactivex.subjects.ReplaySubject
Returns a typed array containing a snapshot of all values of the Subject.
getWrappedRunnable() - Method in interface io.reactivex.schedulers.SchedulerRunnableIntrospection
Returns the wrapped action.
groupBy(Function<? super T, ? extends K>) - Method in class io.reactivex.Flowable
Groups the items emitted by a Publisher according to a specified criterion, and emits these grouped items as GroupedFlowables.
groupBy(Function<? super T, ? extends K>, boolean) - Method in class io.reactivex.Flowable
Groups the items emitted by a Publisher according to a specified criterion, and emits these grouped items as GroupedFlowables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.Flowable
Groups the items emitted by a Publisher according to a specified criterion, and emits these grouped items as GroupedFlowables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean) - Method in class io.reactivex.Flowable
Groups the items emitted by a Publisher according to a specified criterion, and emits these grouped items as GroupedFlowables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean, int) - Method in class io.reactivex.Flowable
Groups the items emitted by a Publisher according to a specified criterion, and emits these grouped items as GroupedFlowables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean, int, Function<? super Consumer<Object>, ? extends Map<K, Object>>) - Method in class io.reactivex.Flowable
Groups the items emitted by a Publisher according to a specified criterion, and emits these grouped items as GroupedFlowables.
groupBy(Function<? super T, ? extends K>) - Method in class io.reactivex.Observable
Groups the items emitted by an ObservableSource according to a specified criterion, and emits these grouped items as GroupedObservables.
groupBy(Function<? super T, ? extends K>, boolean) - Method in class io.reactivex.Observable
Groups the items emitted by an ObservableSource according to a specified criterion, and emits these grouped items as GroupedObservables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.Observable
Groups the items emitted by an ObservableSource according to a specified criterion, and emits these grouped items as GroupedObservables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean) - Method in class io.reactivex.Observable
Groups the items emitted by an ObservableSource according to a specified criterion, and emits these grouped items as GroupedObservables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean, int) - Method in class io.reactivex.Observable
Groups the items emitted by an ObservableSource according to a specified criterion, and emits these grouped items as GroupedObservables.
GroupByObserver(Observer<? super GroupedObservable<K, V>>, Function<? super T, ? extends K>, Function<? super T, ? extends V>, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableGroupBy.GroupByObserver
 
GroupBySubscriber(Subscriber<? super GroupedFlowable<K, V>>, Function<? super T, ? extends K>, Function<? super T, ? extends V>, int, boolean, Map<Object, FlowableGroupBy.GroupedUnicast<K, V>>, Queue<FlowableGroupBy.GroupedUnicast<K, V>>) - Constructor for class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
GroupedFlowable<K,T> - Class in io.reactivex.flowables
A Flowable that has been grouped by key, the value of which can be obtained with GroupedFlowable.getKey().
GroupedFlowable(K) - Constructor for class io.reactivex.flowables.GroupedFlowable
Constructs a GroupedFlowable with the given key.
GroupedObservable<K,T> - Class in io.reactivex.observables
An Observable that has been grouped by key, the value of which can be obtained with GroupedObservable.getKey().
GroupedObservable(K) - Constructor for class io.reactivex.observables.GroupedObservable
Constructs a GroupedObservable with the given key.
groupJoin(Publisher<? extends TRight>, Function<? super T, ? extends Publisher<TLeftEnd>>, Function<? super TRight, ? extends Publisher<TRightEnd>>, BiFunction<? super T, ? super Flowable<TRight>, ? extends R>) - Method in class io.reactivex.Flowable
Returns a Flowable that correlates two Publishers when they overlap in time and groups the results.
groupJoin(ObservableSource<? extends TRight>, Function<? super T, ? extends ObservableSource<TLeftEnd>>, Function<? super TRight, ? extends ObservableSource<TRightEnd>>, BiFunction<? super T, ? super Observable<TRight>, ? extends R>) - Method in class io.reactivex.Observable
Returns an Observable that correlates two ObservableSources when they overlap in time and groups the results.

H

HalfSerializer - Class in io.reactivex.internal.util
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.
hasComplete() - Method in class io.reactivex.processors.AsyncProcessor
 
hasComplete() - Method in class io.reactivex.processors.BehaviorProcessor
 
hasComplete() - Method in class io.reactivex.processors.FlowableProcessor
Returns true if the FlowableProcessor has reached a terminal state through a complete event.
hasComplete() - Method in class io.reactivex.processors.MulticastProcessor
 
hasComplete() - Method in class io.reactivex.processors.PublishProcessor
 
hasComplete() - Method in class io.reactivex.processors.ReplayProcessor
 
hasComplete() - Method in class io.reactivex.processors.UnicastProcessor
 
hasComplete() - Method in class io.reactivex.subjects.AsyncSubject
 
hasComplete() - Method in class io.reactivex.subjects.BehaviorSubject
 
hasComplete() - Method in class io.reactivex.subjects.CompletableSubject
Returns true if this CompletableSubject has been completed.
hasComplete() - Method in class io.reactivex.subjects.MaybeSubject
Returns true if this MaybeSubject has been completed.
hasComplete() - Method in class io.reactivex.subjects.PublishSubject
 
hasComplete() - Method in class io.reactivex.subjects.ReplaySubject
 
hasComplete() - Method in class io.reactivex.subjects.Subject
Returns true if the subject has reached a terminal state through a complete event.
hasComplete() - Method in class io.reactivex.subjects.UnicastSubject
 
hasCustomOnError() - Method in class io.reactivex.internal.observers.CallbackCompletableObserver
 
hasCustomOnError() - Method in class io.reactivex.internal.observers.ConsumerSingleObserver
 
hasCustomOnError() - Method in class io.reactivex.internal.observers.EmptyCompletableObserver
 
hasCustomOnError() - Method in class io.reactivex.internal.observers.LambdaObserver
 
hasCustomOnError() - Method in class io.reactivex.internal.operators.maybe.MaybeCallbackObserver
 
hasCustomOnError() - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
hasCustomOnError() - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
hasCustomOnError() - Method in interface io.reactivex.observers.LambdaConsumerIntrospection
 
hashCode(Object) - Static method in class io.reactivex.internal.functions.ObjectHelper
Returns the hashCode of a non-null object or zero for a null object.
hashCode() - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
hashCode() - Method in class io.reactivex.Notification
 
hashCode() - Method in class io.reactivex.schedulers.Timed
 
HashMapSupplier - Enum in io.reactivex.internal.util
 
hasObservers() - Method in class io.reactivex.subjects.AsyncSubject
 
hasObservers() - Method in class io.reactivex.subjects.BehaviorSubject
 
hasObservers() - Method in class io.reactivex.subjects.CompletableSubject
Returns true if this CompletableSubject has observers.
hasObservers() - Method in class io.reactivex.subjects.MaybeSubject
Returns true if this MaybeSubject has observers.
hasObservers() - Method in class io.reactivex.subjects.PublishSubject
 
hasObservers() - Method in class io.reactivex.subjects.ReplaySubject
 
hasObservers() - Method in class io.reactivex.subjects.SingleSubject
Returns true if this SingleSubject has observers.
hasObservers() - Method in class io.reactivex.subjects.Subject
Returns true if the subject has any Observers.
hasObservers() - Method in class io.reactivex.subjects.UnicastSubject
 
hasSubscribers() - Method in class io.reactivex.processors.AsyncProcessor
 
hasSubscribers() - Method in class io.reactivex.processors.BehaviorProcessor
 
hasSubscribers() - Method in class io.reactivex.processors.FlowableProcessor
Returns true if the FlowableProcessor has subscribers.
hasSubscribers() - Method in class io.reactivex.processors.MulticastProcessor
 
hasSubscribers() - Method in class io.reactivex.processors.PublishProcessor
 
hasSubscribers() - Method in class io.reactivex.processors.ReplayProcessor
 
hasSubscribers() - Method in class io.reactivex.processors.UnicastProcessor
 
hasSubscription() - Method in class io.reactivex.observers.TestObserver
Returns true if this TestObserver received a subscription.
hasSubscription() - Method in class io.reactivex.subscribers.TestSubscriber
Returns true if this TestSubscriber received a subscription.
hasThrowable() - Method in class io.reactivex.processors.AsyncProcessor
 
hasThrowable() - Method in class io.reactivex.processors.BehaviorProcessor
 
hasThrowable() - Method in class io.reactivex.processors.FlowableProcessor
Returns true if the FlowableProcessor has reached a terminal state through an error event.
hasThrowable() - Method in class io.reactivex.processors.MulticastProcessor
 
hasThrowable() - Method in class io.reactivex.processors.PublishProcessor
 
hasThrowable() - Method in class io.reactivex.processors.ReplayProcessor
 
hasThrowable() - Method in class io.reactivex.processors.UnicastProcessor
 
hasThrowable() - Method in class io.reactivex.subjects.AsyncSubject
 
hasThrowable() - Method in class io.reactivex.subjects.BehaviorSubject
 
hasThrowable() - Method in class io.reactivex.subjects.CompletableSubject
Returns true if this CompletableSubject has been terminated with an error.
hasThrowable() - Method in class io.reactivex.subjects.MaybeSubject
Returns true if this MaybeSubject has been terminated with an error.
hasThrowable() - Method in class io.reactivex.subjects.PublishSubject
 
hasThrowable() - Method in class io.reactivex.subjects.ReplaySubject
 
hasThrowable() - Method in class io.reactivex.subjects.SingleSubject
Returns true if this SingleSubject has been terminated with an error.
hasThrowable() - Method in class io.reactivex.subjects.Subject
Returns true if the subject has reached a terminal state through an error event.
hasThrowable() - Method in class io.reactivex.subjects.UnicastSubject
 
HasUpstreamCompletableSource - Interface in io.reactivex.internal.fuseable
Interface indicating the implementor has an upstream CompletableSource-like source available via HasUpstreamCompletableSource.source() method.
HasUpstreamMaybeSource<T> - Interface in io.reactivex.internal.fuseable
Interface indicating the implementor has an upstream MaybeSource-like source available via HasUpstreamMaybeSource.source() method.
HasUpstreamObservableSource<T> - Interface in io.reactivex.internal.fuseable
Interface indicating the implementor has an upstream ObservableSource-like source available via HasUpstreamObservableSource.source() method.
HasUpstreamPublisher<T> - Interface in io.reactivex.internal.fuseable
Interface indicating the implementor has an upstream Publisher-like source available via HasUpstreamPublisher.source() method.
HasUpstreamSingleSource<T> - Interface in io.reactivex.internal.fuseable
Interface indicating the implementor has an upstream SingleSource-like source available via HasUpstreamSingleSource.source() method.
hasValue - Variable in class io.reactivex.internal.subscribers.DeferredScalarSubscriber
Can indicate if there was at least on onNext call.
hasValue() - Method in class io.reactivex.processors.AsyncProcessor
Returns true if this processor has any value.
hasValue() - Method in class io.reactivex.processors.BehaviorProcessor
Returns true if the BehaviorProcessor has any value.
hasValue() - Method in class io.reactivex.processors.ReplayProcessor
Returns true if this processor has any value.
hasValue() - Method in class io.reactivex.subjects.AsyncSubject
Returns true if the subject has any value.
hasValue() - Method in class io.reactivex.subjects.BehaviorSubject
Returns true if the subject has any value.
hasValue() - Method in class io.reactivex.subjects.MaybeSubject
Returns true if this MaybeSubject was terminated with a success value.
hasValue() - Method in class io.reactivex.subjects.ReplaySubject
Returns true if the subject has any value.
hasValue() - Method in class io.reactivex.subjects.SingleSubject
Returns true if this SingleSubject was terminated with a success value.
head() - Method in class io.reactivex.internal.util.LinkedArrayList
Returns the head buffer segment or null if the list is empty.
hide() - Method in class io.reactivex.Completable
Hides the identity of this Completable and its Disposable.
hide() - Method in class io.reactivex.Flowable
Hides the identity of this Flowable and its Subscription.
hide() - Method in class io.reactivex.Maybe
Hides the identity of this Maybe and its Disposable.
hide() - Method in class io.reactivex.Observable
Hides the identity of this Observable and its Disposable.
hide() - Method in class io.reactivex.Single
Hides the identity of the current Single, including the Disposable that is sent to the downstream via onSubscribe().

I

identity() - Static method in class io.reactivex.internal.functions.Functions
Returns an identity function that simply returns its argument.
ignoreElement() - Method in class io.reactivex.Maybe
Ignores the item emitted by the source Maybe and only calls onComplete or onError.
ignoreElement() - Method in class io.reactivex.Single
Returns a Completable that ignores the success value of this Single and calls onComplete instead on the returned Completable.
ignoreElements() - Method in class io.reactivex.Flowable
Ignores all items emitted by the source Publisher and only calls onComplete or onError.
ignoreElements() - Method in class io.reactivex.Observable
Ignores all items emitted by the source ObservableSource and only calls onComplete or onError.
ImmediateThinScheduler - Class in io.reactivex.internal.schedulers
A Scheduler partially implementing the API by allowing only non-delayed, non-periodic task execution on the current thread immediately.
indexOf(Object) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
initComputationScheduler(Callable<Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
initialFusionMode - Variable in class io.reactivex.observers.BaseTestConsumer
 
initIoScheduler(Callable<Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
initNewThreadScheduler(Callable<Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
initSingleScheduler(Callable<Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
innerComplete(InnerQueuedObserver<T>) - Method in interface io.reactivex.internal.observers.InnerQueuedObserverSupport
 
innerComplete(InnerQueuedSubscriber<T>) - Method in interface io.reactivex.internal.subscribers.InnerQueuedSubscriberSupport
 
innerError(InnerQueuedObserver<T>, Throwable) - Method in interface io.reactivex.internal.observers.InnerQueuedObserverSupport
 
innerError(InnerQueuedSubscriber<T>, Throwable) - Method in interface io.reactivex.internal.subscribers.InnerQueuedSubscriberSupport
 
innerNext(InnerQueuedObserver<T>, T) - Method in interface io.reactivex.internal.observers.InnerQueuedObserverSupport
 
innerNext(InnerQueuedSubscriber<T>, T) - Method in interface io.reactivex.internal.subscribers.InnerQueuedSubscriberSupport
 
InnerQueuedObserver<T> - Class in io.reactivex.internal.observers
Subscriber that can fuse with the upstream and calls a support interface whenever an event is available.
InnerQueuedObserver(InnerQueuedObserverSupport<T>, int) - Constructor for class io.reactivex.internal.observers.InnerQueuedObserver
 
InnerQueuedObserverSupport<T> - Interface in io.reactivex.internal.observers
Interface to allow the InnerQueuedSubscriber to call back a parent with signals.
InnerQueuedSubscriber<T> - Class in io.reactivex.internal.subscribers
Subscriber that can fuse with the upstream and calls a support interface whenever an event is available.
InnerQueuedSubscriber(InnerQueuedSubscriberSupport<T>, int) - Constructor for class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
InnerQueuedSubscriberSupport<T> - Interface in io.reactivex.internal.subscribers
Interface to allow the InnerQueuedSubscriber to call back a parent with signals.
INSTANCE - Static variable in class io.reactivex.internal.operators.completable.CompletableEmpty
 
INSTANCE - Static variable in class io.reactivex.internal.operators.completable.CompletableNever
 
INSTANCE - Static variable in class io.reactivex.internal.operators.flowable.FlowableEmpty
 
INSTANCE - Static variable in class io.reactivex.internal.operators.flowable.FlowableNever
 
INSTANCE - Static variable in class io.reactivex.internal.operators.maybe.MaybeEmpty
 
INSTANCE - Static variable in class io.reactivex.internal.operators.maybe.MaybeNever
 
instance() - Static method in enum io.reactivex.internal.operators.maybe.MaybeToPublisher
 
INSTANCE - Static variable in class io.reactivex.internal.operators.observable.ObservableEmpty
 
INSTANCE - Static variable in class io.reactivex.internal.operators.observable.ObservableNever
 
INSTANCE - Static variable in class io.reactivex.internal.operators.single.SingleNever
 
INSTANCE - Static variable in class io.reactivex.internal.schedulers.ImmediateThinScheduler
The singleton instance of the immediate (thin) scheduler.
instance() - Static method in class io.reactivex.internal.schedulers.TrampolineScheduler
 
instance() - Static method in enum io.reactivex.internal.util.ListAddBiConsumer
 
interval(long, long, TimeUnit) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits a 0L after the initialDelay and ever-increasing numbers after each period of time thereafter.
interval(long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits a 0L after the initialDelay and ever-increasing numbers after each period of time thereafter, on a specified Scheduler.
interval(long, TimeUnit) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits a sequential number every specified interval of time.
interval(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits a sequential number every specified interval of time, on a specified Scheduler.
interval(long, long, TimeUnit) - Static method in class io.reactivex.Observable
Returns an Observable that emits a 0L after the initialDelay and ever increasing numbers after each period of time thereafter.
interval(long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Observable
Returns an Observable that emits a 0L after the initialDelay and ever increasing numbers after each period of time thereafter, on a specified Scheduler.
interval(long, TimeUnit) - Static method in class io.reactivex.Observable
Returns an Observable that emits a sequential number every specified interval of time.
interval(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Observable
Returns an Observable that emits a sequential number every specified interval of time, on a specified Scheduler.
intervalRange(long, long, long, long, TimeUnit) - Static method in class io.reactivex.Flowable
Signals a range of long values, the first after some initial delay and the rest periodically after.
intervalRange(long, long, long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Flowable
Signals a range of long values, the first after some initial delay and the rest periodically after.
intervalRange(long, long, long, long, TimeUnit) - Static method in class io.reactivex.Observable
Signals a range of long values, the first after some initial delay and the rest periodically after.
intervalRange(long, long, long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Observable
Signals a range of long values, the first after some initial delay and the rest periodically after.
IntFunction<T> - Interface in io.reactivex.functions
A functional interface (callback) that takes a primitive value and return value of type T.
IO - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
The operator/class runs on RxJava's I/O scheduler or takes timing information from it.
io() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, shared Scheduler instance intended for IO-bound work.
io.reactivex - package io.reactivex
Base reactive classes: Flowable, Observable, Single, Maybe and Completable; base reactive consumers; other common base interfaces.
io.reactivex.annotations - package io.reactivex.annotations
Annotations for indicating experimental and beta operators, classes, methods, types or fields.
io.reactivex.disposables - package io.reactivex.disposables
Default implementations for Disposable-based resource management (Disposable container types) and utility classes to construct Disposables from callbacks and other types.
io.reactivex.exceptions - package io.reactivex.exceptions
Exception handling utilities, safe subscriber exception classes, lifecycle exception classes.
io.reactivex.flowables - package io.reactivex.flowables
Classes supporting the Flowable base reactive class: ConnectableFlowable and GroupedFlowable.
io.reactivex.functions - package io.reactivex.functions
Functional interfaces of functions and actions of arity 0 to 9 and related utility classes.
io.reactivex.internal.disposables - package io.reactivex.internal.disposables
 
io.reactivex.internal.functions - package io.reactivex.internal.functions
 
io.reactivex.internal.fuseable - package io.reactivex.internal.fuseable
Base interfaces and types for supporting operator-fusion.
io.reactivex.internal.observers - package io.reactivex.internal.observers
 
io.reactivex.internal.operators.completable - package io.reactivex.internal.operators.completable
 
io.reactivex.internal.operators.flowable - package io.reactivex.internal.operators.flowable
 
io.reactivex.internal.operators.maybe - package io.reactivex.internal.operators.maybe
 
io.reactivex.internal.operators.mixed - package io.reactivex.internal.operators.mixed
 
io.reactivex.internal.operators.observable - package io.reactivex.internal.operators.observable
 
io.reactivex.internal.operators.parallel - package io.reactivex.internal.operators.parallel
 
io.reactivex.internal.operators.single - package io.reactivex.internal.operators.single
 
io.reactivex.internal.queue - package io.reactivex.internal.queue
 
io.reactivex.internal.schedulers - package io.reactivex.internal.schedulers
 
io.reactivex.internal.subscribers - package io.reactivex.internal.subscribers
 
io.reactivex.internal.subscriptions - package io.reactivex.internal.subscriptions
 
io.reactivex.internal.util - package io.reactivex.internal.util
 
io.reactivex.observables - package io.reactivex.observables
Classes supporting the Observable base reactive class: ConnectableObservable and GroupedObservable.
io.reactivex.observers - package io.reactivex.observers
Default wrappers and implementations for Observer-based consumer classes and interfaces, including disposable and resource-tracking variants and the TestObserver that allows unit testing Observable-, Single-, Maybe- and Completable-based flows.
io.reactivex.parallel - package io.reactivex.parallel
Contains the base type ParallelFlowable, a sub-DSL for working with Flowable sequences in parallel.
io.reactivex.plugins - package io.reactivex.plugins
Contains the central plugin handler RxJavaPlugins class to hook into the lifecycle of the base reactive types and schedulers.
io.reactivex.processors - package io.reactivex.processors
Classes extending the Flowable base reactive class and implementing the Subscriber interface at the same time (aka hot Flowables).
io.reactivex.schedulers - package io.reactivex.schedulers
Scheduler implementations, value+time record class and the standard factory class to return standard RxJava schedulers or wrap any Executor-based (thread pool) instances.
io.reactivex.subjects - package io.reactivex.subjects
Classes representing so-called hot sources, aka subjects, that implement a base reactive class and the respective consumer type at once to allow forms of multicasting events to multiple consumers as well as consuming another base reactive type of their kind.
io.reactivex.subscribers - package io.reactivex.subscribers
Default wrappers and implementations for Subscriber-based consumer classes and interfaces, including disposable and resource-tracking variants and the TestSubscriber that allows unit testing Flowable-based flows.
IoScheduler - Class in io.reactivex.internal.schedulers
Scheduler that creates and caches a set of thread pools and reuses them if possible.
IoScheduler() - Constructor for class io.reactivex.internal.schedulers.IoScheduler
 
IoScheduler(ThreadFactory) - Constructor for class io.reactivex.internal.schedulers.IoScheduler
 
isCancelled() - Method in interface io.reactivex.FlowableEmitter
Returns true if the downstream cancelled the sequence or the emitter was terminated via Emitter.onError(Throwable), Emitter.onComplete() or a successful FlowableEmitter.tryOnError(Throwable).
isCancelled() - Method in class io.reactivex.internal.observers.FutureObserver
 
isCancelled() - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
isCancelled() - Method in class io.reactivex.internal.subscribers.BlockingSubscriber
 
isCancelled() - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
isCancelled() - Method in class io.reactivex.internal.subscriptions.BooleanSubscription
Returns true if this BooleanSubscription has been cancelled.
isCancelled() - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
Returns true if this Subscription has been cancelled.
isCancelled() - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
Returns true if this Subscription was cancelled.
isCancelled() - Method in class io.reactivex.internal.subscriptions.SubscriptionArbiter
Returns true if the arbiter has been cancelled.
isCancelled(Subscription) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Check if the given subscription is the common cancelled subscription.
isCancelled() - Method in class io.reactivex.observers.TestObserver
Returns true if this TestObserver has been cancelled.
isCancelled() - Method in class io.reactivex.subscribers.TestSubscriber
Returns true if this TestSubscriber has been cancelled.
isComplete(Object) - Static method in enum io.reactivex.internal.util.NotificationLite
Checks if the given object represents a complete notification.
isDisposable(Object) - Static method in enum io.reactivex.internal.util.NotificationLite
 
isDisposed() - Method in interface io.reactivex.CompletableEmitter
Returns true if the downstream disposed the sequence or the emitter was terminated via CompletableEmitter.onError(Throwable), CompletableEmitter.onComplete() or a successful CompletableEmitter.tryOnError(Throwable).
isDisposed() - Method in class io.reactivex.disposables.CompositeDisposable
 
isDisposed() - Method in interface io.reactivex.disposables.Disposable
Returns true if this resource has been disposed.
isDisposed() - Method in class io.reactivex.disposables.SerialDisposable
 
isDisposed() - Method in class io.reactivex.internal.disposables.ArrayCompositeDisposable
 
isDisposed() - Method in class io.reactivex.internal.disposables.CancellableDisposable
 
isDisposed(Disposable) - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Checks if the given Disposable is the common DisposableHelper.DISPOSED enum value.
isDisposed() - Method in enum io.reactivex.internal.disposables.DisposableHelper
 
isDisposed() - Method in enum io.reactivex.internal.disposables.EmptyDisposable
 
isDisposed() - Method in class io.reactivex.internal.disposables.ListCompositeDisposable
 
isDisposed() - Method in class io.reactivex.internal.disposables.SequentialDisposable
 
isDisposed() - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.BiConsumerSingleObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.BlockingBaseObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.BlockingObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.CallbackCompletableObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.ConsumerSingleObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
 
isDisposed() - Method in class io.reactivex.internal.observers.DisposableLambdaObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.EmptyCompletableObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.ForEachWhileObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.FutureObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
isDisposed() - Method in class io.reactivex.internal.observers.LambdaObserver
 
isDisposed() - Method in class io.reactivex.internal.operators.flowable.FlowableReplay
 
isDisposed() - Method in class io.reactivex.internal.operators.maybe.MaybeCallbackObserver
 
isDisposed() - Method in class io.reactivex.internal.operators.observable.ObservableGroupBy.GroupByObserver
 
isDisposed() - Method in class io.reactivex.internal.operators.observable.ObservableReplay
 
isDisposed() - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
isDisposed() - Method in class io.reactivex.internal.operators.observable.ObserverResourceWrapper
 
isDisposed() - Method in class io.reactivex.internal.schedulers.ExecutorScheduler.ExecutorWorker
 
isDisposed() - Method in class io.reactivex.internal.schedulers.NewThreadWorker
 
isDisposed() - Method in class io.reactivex.internal.schedulers.ScheduledRunnable
 
isDisposed() - Method in class io.reactivex.internal.schedulers.SchedulerWhen
 
isDisposed() - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
isDisposed() - Method in class io.reactivex.internal.subscribers.ForEachWhileSubscriber
 
isDisposed() - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
isDisposed() - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
isDisposed() - Method in class io.reactivex.internal.subscriptions.ArrayCompositeSubscription
 
isDisposed() - Method in class io.reactivex.internal.subscriptions.AsyncSubscription
 
isDisposed() - Method in enum io.reactivex.internal.util.EmptyComponent
 
isDisposed() - Method in interface io.reactivex.MaybeEmitter
Returns true if the downstream disposed the sequence or the emitter was terminated via MaybeEmitter.onSuccess(Object), MaybeEmitter.onError(Throwable), MaybeEmitter.onComplete() or a successful MaybeEmitter.tryOnError(Throwable).
isDisposed() - Method in interface io.reactivex.ObservableEmitter
Returns true if the downstream disposed the sequence or the emitter was terminated via Emitter.onError(Throwable), Emitter.onComplete() or a successful ObservableEmitter.tryOnError(Throwable).
isDisposed() - Method in class io.reactivex.observers.DisposableCompletableObserver
 
isDisposed() - Method in class io.reactivex.observers.DisposableMaybeObserver
 
isDisposed() - Method in class io.reactivex.observers.DisposableObserver
 
isDisposed() - Method in class io.reactivex.observers.DisposableSingleObserver
 
isDisposed() - Method in class io.reactivex.observers.ResourceCompletableObserver
Returns true if this ResourceObserver has been disposed/cancelled.
isDisposed() - Method in class io.reactivex.observers.ResourceMaybeObserver
Returns true if this ResourceObserver has been disposed/cancelled.
isDisposed() - Method in class io.reactivex.observers.ResourceObserver
Returns true if this ResourceObserver has been disposed/cancelled.
isDisposed() - Method in class io.reactivex.observers.ResourceSingleObserver
Returns true if this ResourceObserver has been disposed/cancelled.
isDisposed() - Method in class io.reactivex.observers.SafeObserver
 
isDisposed() - Method in class io.reactivex.observers.SerializedObserver
 
isDisposed() - Method in class io.reactivex.observers.TestObserver
 
isDisposed() - Method in interface io.reactivex.SingleEmitter
Returns true if the downstream disposed the sequence or the emitter was terminated via SingleEmitter.onSuccess(Object), SingleEmitter.onError(Throwable), or a successful SingleEmitter.tryOnError(Throwable).
isDisposed() - Method in class io.reactivex.subscribers.DisposableSubscriber
 
isDisposed() - Method in class io.reactivex.subscribers.ResourceSubscriber
Returns true if this AsyncObserver has been disposed/cancelled.
isDisposed() - Method in class io.reactivex.subscribers.TestSubscriber
 
isDone() - Method in class io.reactivex.internal.observers.FutureObserver
 
isDone() - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
isDone() - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
isDone() - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
isDone() - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
isEmpty() - Method in class io.reactivex.Flowable
Returns a Single that emits true if the source Publisher is empty, otherwise false.
isEmpty() - Method in enum io.reactivex.internal.disposables.EmptyDisposable
 
isEmpty() - Method in interface io.reactivex.internal.fuseable.SimpleQueue
Returns true if the queue is empty.
isEmpty() - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
isEmpty() - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
 
isEmpty() - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
isEmpty() - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
isEmpty() - Method in class io.reactivex.internal.queue.MpscLinkedQueue
Returns true if the queue is empty.
isEmpty() - Method in class io.reactivex.internal.queue.SpscArrayQueue
 
isEmpty() - Method in class io.reactivex.internal.queue.SpscLinkedArrayQueue
 
isEmpty() - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
isEmpty() - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
isEmpty() - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
 
isEmpty() - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
isEmpty() - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
 
isEmpty() - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
isEmpty() - Method in class io.reactivex.Maybe
Returns a Single that emits true if the source Maybe is empty, otherwise false.
isEmpty() - Method in class io.reactivex.Observable
Returns a Single that emits true if the source ObservableSource is empty, otherwise false.
isError(Object) - Static method in enum io.reactivex.internal.util.NotificationLite
Checks if the given object represents a error notification.
isFailOnNonBlockingScheduler() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns true if the blockingX operators fail with an IllegalStateException on a non-blocking scheduler such as computation or single.
isInstanceOf(Class<U>) - Static method in class io.reactivex.internal.functions.Functions
 
isLockdown() - Static method in class io.reactivex.plugins.RxJavaPlugins
Returns true if the plugins were locked down.
isOnComplete() - Method in class io.reactivex.Notification
Returns true if this notification is an onComplete signal.
isOnError() - Method in class io.reactivex.Notification
Returns true if this notification is an onError signal and Notification.getError() returns the contained Throwable.
isOnNext() - Method in class io.reactivex.Notification
Returns true if this notification is an onNext signal and Notification.getValue() returns the contained value.
isPowerOfTwo(int) - Static method in class io.reactivex.internal.util.Pow2
Is this value a power of two.
isSubscription(Object) - Static method in enum io.reactivex.internal.util.NotificationLite
Checks if the given object represents a subscription notification.
isTerminated() - Method in class io.reactivex.internal.util.AtomicThrowable
 
isTerminated() - Method in class io.reactivex.observers.BaseTestConsumer
Returns true if TestObserver/TestSubscriber received any onError or onComplete events.
isTimeout() - Method in class io.reactivex.observers.BaseTestConsumer
 
isUnbounded() - Method in class io.reactivex.internal.subscriptions.SubscriptionArbiter
Returns true if the arbiter runs in unbounded mode.
itemDelay(Function<? super T, ? extends Publisher<U>>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
itemDelay(Function<? super T, ? extends ObservableSource<U>>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
iterableToFlowable(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.internal.operators.single.SingleInternalHelper
 
iterator() - Method in class io.reactivex.internal.operators.flowable.BlockingFlowableIterable
 
iterator() - Method in class io.reactivex.internal.operators.flowable.BlockingFlowableLatest
 
iterator() - Method in class io.reactivex.internal.operators.flowable.BlockingFlowableMostRecent
 
iterator() - Method in class io.reactivex.internal.operators.flowable.BlockingFlowableNext
 
iterator() - Method in class io.reactivex.internal.operators.observable.BlockingObservableIterable
 
iterator() - Method in class io.reactivex.internal.operators.observable.BlockingObservableLatest
 
iterator() - Method in class io.reactivex.internal.operators.observable.BlockingObservableMostRecent
 
iterator() - Method in class io.reactivex.internal.operators.observable.BlockingObservableNext
 
iterator() - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 

J

join(Publisher<? extends TRight>, Function<? super T, ? extends Publisher<TLeftEnd>>, Function<? super TRight, ? extends Publisher<TRightEnd>>, BiFunction<? super T, ? super TRight, ? extends R>) - Method in class io.reactivex.Flowable
Correlates the items emitted by two Publishers based on overlapping durations.
join(ObservableSource<? extends TRight>, Function<? super T, ? extends ObservableSource<TLeftEnd>>, Function<? super TRight, ? extends ObservableSource<TRightEnd>>, BiFunction<? super T, ? super TRight, ? extends R>) - Method in class io.reactivex.Observable
Correlates the items emitted by two ObservableSources based on overlapping durations.
just(T) - Static method in class io.reactivex.Flowable
Returns a Flowable that signals the given (constant reference) item and then completes.
just(T, T) - Static method in class io.reactivex.Flowable
Converts two items into a Publisher that emits those items.
just(T, T, T) - Static method in class io.reactivex.Flowable
Converts three items into a Publisher that emits those items.
just(T, T, T, T) - Static method in class io.reactivex.Flowable
Converts four items into a Publisher that emits those items.
just(T, T, T, T, T) - Static method in class io.reactivex.Flowable
Converts five items into a Publisher that emits those items.
just(T, T, T, T, T, T) - Static method in class io.reactivex.Flowable
Converts six items into a Publisher that emits those items.
just(T, T, T, T, T, T, T) - Static method in class io.reactivex.Flowable
Converts seven items into a Publisher that emits those items.
just(T, T, T, T, T, T, T, T) - Static method in class io.reactivex.Flowable
Converts eight items into a Publisher that emits those items.
just(T, T, T, T, T, T, T, T, T) - Static method in class io.reactivex.Flowable
Converts nine items into a Publisher that emits those items.
just(T, T, T, T, T, T, T, T, T, T) - Static method in class io.reactivex.Flowable
Converts ten items into a Publisher that emits those items.
just(T) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits a specified item.
just(T) - Static method in class io.reactivex.Observable
Returns an Observable that signals the given (constant reference) item and then completes.
just(T, T) - Static method in class io.reactivex.Observable
Converts two items into an ObservableSource that emits those items.
just(T, T, T) - Static method in class io.reactivex.Observable
Converts three items into an ObservableSource that emits those items.
just(T, T, T, T) - Static method in class io.reactivex.Observable
Converts four items into an ObservableSource that emits those items.
just(T, T, T, T, T) - Static method in class io.reactivex.Observable
Converts five items into an ObservableSource that emits those items.
just(T, T, T, T, T, T) - Static method in class io.reactivex.Observable
Converts six items into an ObservableSource that emits those items.
just(T, T, T, T, T, T, T) - Static method in class io.reactivex.Observable
Converts seven items into an ObservableSource that emits those items.
just(T, T, T, T, T, T, T, T) - Static method in class io.reactivex.Observable
Converts eight items into an ObservableSource that emits those items.
just(T, T, T, T, T, T, T, T, T) - Static method in class io.reactivex.Observable
Converts nine items into an ObservableSource that emits those items.
just(T, T, T, T, T, T, T, T, T, T) - Static method in class io.reactivex.Observable
Converts ten items into an ObservableSource that emits those items.
just(T) - Static method in class io.reactivex.Single
Returns a Single that emits a specified item.
justCallable(T) - Static method in class io.reactivex.internal.functions.Functions
Returns a Callable that returns the given value.
justFunction(U) - Static method in class io.reactivex.internal.functions.Functions
Returns a Function that ignores its parameter and returns the given value.

K

keys() - Method in class io.reactivex.internal.util.OpenHashSet
 

L

LambdaConsumerIntrospection - Interface in io.reactivex.observers
An interface that indicates that the implementing type is composed of individual components and exposes information about their behavior.
LambdaObserver<T> - Class in io.reactivex.internal.observers
 
LambdaObserver(Consumer<? super T>, Consumer<? super Throwable>, Action, Consumer<? super Disposable>) - Constructor for class io.reactivex.internal.observers.LambdaObserver
 
LambdaSubscriber<T> - Class in io.reactivex.internal.subscribers
 
LambdaSubscriber(Consumer<? super T>, Consumer<? super Throwable>, Action, Consumer<? super Subscription>) - Constructor for class io.reactivex.internal.subscribers.LambdaSubscriber
 
last(T) - Method in class io.reactivex.Flowable
Returns a Single that emits only the last item emitted by this Flowable, or a default item if this Flowable completes without emitting any items.
last(T) - Method in class io.reactivex.Observable
Returns a Single that emits only the last item emitted by this Observable, or a default item if this Observable completes without emitting any items.
lastElement() - Method in class io.reactivex.Flowable
Returns a Maybe that emits the last item emitted by this Flowable or completes if this Flowable is empty.
lastElement() - Method in class io.reactivex.Observable
Returns a Maybe that emits the last item emitted by this Observable or completes if this Observable is empty.
lastIndexOf(Object) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
lastOrError() - Method in class io.reactivex.Flowable
Returns a Single that emits only the last item emitted by this Flowable or signals a NoSuchElementException if this Flowable is empty.
lastOrError() - Method in class io.reactivex.Observable
Returns a Single that emits only the last item emitted by this Observable or signals a NoSuchElementException if this Observable is empty.
lastThread - Variable in class io.reactivex.observers.BaseTestConsumer
The last thread seen by the observer.
lastThread() - Method in class io.reactivex.observers.BaseTestConsumer
Returns the last thread which called the onXXX methods of this TestObserver/TestSubscriber.
leave(int) - Method in class io.reactivex.internal.observers.QueueDrainObserver
 
leave(int) - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
leave(int) - Method in interface io.reactivex.internal.util.ObservableQueueDrain
Adds m to the wip counter.
leave(int) - Method in interface io.reactivex.internal.util.QueueDrain
Adds m to the wip counter.
lift(CompletableOperator) - Method in class io.reactivex.Completable
This method requires advanced knowledge about building operators, please consider other standard composition methods first; Returns a Completable which, when subscribed to, invokes the apply(CompletableObserver) method of the provided CompletableOperator for each individual downstream Completable and allows the insertion of a custom operator by accessing the downstream's CompletableObserver during this subscription phase and providing a new CompletableObserver, containing the custom operator's intended business logic, that will be used in the subscription process going further upstream.
lift(FlowableOperator<? extends R, ? super T>) - Method in class io.reactivex.Flowable
This method requires advanced knowledge about building operators, please consider other standard composition methods first; Returns a Flowable which, when subscribed to, invokes the apply(Subscriber) method of the provided FlowableOperator for each individual downstream Subscriber and allows the insertion of a custom operator by accessing the downstream's Subscriber during this subscription phase and providing a new Subscriber, containing the custom operator's intended business logic, that will be used in the subscription process going further upstream.
lift(MaybeOperator<? extends R, ? super T>) - Method in class io.reactivex.Maybe
This method requires advanced knowledge about building operators, please consider other standard composition methods first; Returns a Maybe which, when subscribed to, invokes the apply(MaybeObserver) method of the provided MaybeOperator for each individual downstream Maybe and allows the insertion of a custom operator by accessing the downstream's MaybeObserver during this subscription phase and providing a new MaybeObserver, containing the custom operator's intended business logic, that will be used in the subscription process going further upstream.
lift(ObservableOperator<? extends R, ? super T>) - Method in class io.reactivex.Observable
This method requires advanced knowledge about building operators, please consider other standard composition methods first; Returns an Observable which, when subscribed to, invokes the apply(Observer) method of the provided ObservableOperator for each individual downstream Observer and allows the insertion of a custom operator by accessing the downstream's Observer during this subscription phase and providing a new Observer, containing the custom operator's intended business logic, that will be used in the subscription process going further upstream.
lift(SingleOperator<? extends R, ? super T>) - Method in class io.reactivex.Single
This method requires advanced knowledge about building operators, please consider other standard composition methods first; Returns a Single which, when subscribed to, invokes the apply(SingleObserver) method of the provided SingleOperator for each individual downstream Single and allows the insertion of a custom operator by accessing the downstream's SingleObserver during this subscription phase and providing a new SingleObserver, containing the custom operator's intended business logic, that will be used in the subscription process going further upstream.
limit(long) - Method in class io.reactivex.Flowable
Limits both the number of upstream items (after which the sequence completes) and the total downstream request amount requested from the upstream to possibly prevent the creation of excess items by the upstream.
LinkedArrayList - Class in io.reactivex.internal.util
A list implementation which combines an ArrayList with a LinkedList to avoid copying values when the capacity needs to be increased.
LinkedArrayList(int) - Constructor for class io.reactivex.internal.util.LinkedArrayList
Constructor with the capacity hint of each array segment.
ListAddBiConsumer - Enum in io.reactivex.internal.util
 
ListCompositeDisposable - Class in io.reactivex.internal.disposables
A disposable container that can hold onto multiple other disposables.
ListCompositeDisposable() - Constructor for class io.reactivex.internal.disposables.ListCompositeDisposable
 
ListCompositeDisposable(Disposable...) - Constructor for class io.reactivex.internal.disposables.ListCompositeDisposable
 
ListCompositeDisposable(Iterable<? extends Disposable>) - Constructor for class io.reactivex.internal.disposables.ListCompositeDisposable
 
listIterator() - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
listIterator(int) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
listSorter(Comparator<? super T>) - Static method in class io.reactivex.internal.functions.Functions
 
lockdown() - Static method in class io.reactivex.plugins.RxJavaPlugins
Prevents changing the plugins from then on.
LongConsumer - Interface in io.reactivex.functions
A functional interface (callback) that consumes a primitive long value.

M

map(Function<? super T, ? extends R>) - Method in class io.reactivex.Flowable
Returns a Flowable that applies a specified function to each item emitted by the source Publisher and emits the results of these function applications.
map(Function<? super T, ? extends R>) - Method in class io.reactivex.Maybe
Returns a Maybe that applies a specified function to the item emitted by the source Maybe and emits the result of this function application.
map(Function<? super T, ? extends R>) - Method in class io.reactivex.Observable
Returns an Observable that applies a specified function to each item emitted by the source ObservableSource and emits the results of these function applications.
map(Function<? super T, ? extends R>) - Method in class io.reactivex.parallel.ParallelFlowable
Maps the source values on each 'rail' to another value.
map(Function<? super T, ? extends R>, ParallelFailureHandling) - Method in class io.reactivex.parallel.ParallelFlowable
Maps the source values on each 'rail' to another value and handles errors based on the given ParallelFailureHandling enumeration value.
map(Function<? super T, ? extends R>, BiFunction<? super Long, ? super Throwable, ParallelFailureHandling>) - Method in class io.reactivex.parallel.ParallelFlowable
Maps the source values on each 'rail' to another value and handles errors based on the returned value by the handler function.
map(Function<? super T, ? extends R>) - Method in class io.reactivex.Single
Returns a Single that applies a specified function to the item emitted by the source Single and emits the result of this function application.
materialize() - Method in class io.reactivex.Flowable
Returns a Flowable that represents all of the emissions and notifications from the source Publisher into emissions marked with their original types within Notification objects.
materialize() - Method in class io.reactivex.Observable
Returns an Observable that represents all of the emissions and notifications from the source ObservableSource into emissions marked with their original types within Notification objects.
Maybe<T> - Class in io.reactivex
Represents a deferred computation and emission of a maybe value or exception.
Maybe() - Constructor for class io.reactivex.Maybe
 
MaybeAmb<T> - Class in io.reactivex.internal.operators.maybe
Signals the event of the first MaybeSource that signals.
MaybeAmb(MaybeSource<? extends T>[], Iterable<? extends MaybeSource<? extends T>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeAmb
 
MaybeCache<T> - Class in io.reactivex.internal.operators.maybe
Consumes the source once and replays its signal to any current or future MaybeObservers.
MaybeCache(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeCache
 
MaybeCallbackObserver<T> - Class in io.reactivex.internal.operators.maybe
MaybeObserver that delegates the onSuccess, onError and onComplete method calls to callbacks.
MaybeCallbackObserver(Consumer<? super T>, Consumer<? super Throwable>, Action) - Constructor for class io.reactivex.internal.operators.maybe.MaybeCallbackObserver
 
MaybeConcatArray<T> - Class in io.reactivex.internal.operators.maybe
Concatenate values of each MaybeSource provided in an array.
MaybeConcatArray(MaybeSource<? extends T>[]) - Constructor for class io.reactivex.internal.operators.maybe.MaybeConcatArray
 
MaybeConcatArrayDelayError<T> - Class in io.reactivex.internal.operators.maybe
Concatenate values of each MaybeSource provided in an array and delays any errors till the very end.
MaybeConcatArrayDelayError(MaybeSource<? extends T>[]) - Constructor for class io.reactivex.internal.operators.maybe.MaybeConcatArrayDelayError
 
MaybeConcatIterable<T> - Class in io.reactivex.internal.operators.maybe
Concatenate values of each MaybeSource provided by an Iterable.
MaybeConcatIterable(Iterable<? extends MaybeSource<? extends T>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeConcatIterable
 
MaybeContains<T> - Class in io.reactivex.internal.operators.maybe
Signals true if the source signals a value that is object-equals with the provided value, false otherwise or for empty sources.
MaybeContains(MaybeSource<T>, Object) - Constructor for class io.reactivex.internal.operators.maybe.MaybeContains
 
MaybeConverter<T,R> - Interface in io.reactivex
Convenience interface and callback used by the Maybe.as(io.reactivex.MaybeConverter<T, ? extends R>) operator to turn a Maybe into another value fluently.
MaybeCount<T> - Class in io.reactivex.internal.operators.maybe
Signals 1L if the source signalled an item or 0L if the source is empty.
MaybeCount(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeCount
 
MaybeCreate<T> - Class in io.reactivex.internal.operators.maybe
Provides an API over MaybeObserver that serializes calls to onXXX and manages cancellation in a safe manner.
MaybeCreate(MaybeOnSubscribe<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeCreate
 
MaybeDefer<T> - Class in io.reactivex.internal.operators.maybe
Defers the creation of the actual Maybe the incoming MaybeObserver is subscribed to.
MaybeDefer(Callable<? extends MaybeSource<? extends T>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDefer
 
MaybeDelay<T> - Class in io.reactivex.internal.operators.maybe
Delays all signal types by the given amount and re-emits them on the given scheduler.
MaybeDelay(MaybeSource<T>, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDelay
 
MaybeDelayOtherPublisher<T,U> - Class in io.reactivex.internal.operators.maybe
Delay the emission of the main signal until the other signals an item or completes.
MaybeDelayOtherPublisher(MaybeSource<T>, Publisher<U>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDelayOtherPublisher
 
MaybeDelaySubscriptionOtherPublisher<T,U> - Class in io.reactivex.internal.operators.maybe
Delay the subscription to the main Maybe until the other signals an item or completes.
MaybeDelaySubscriptionOtherPublisher(MaybeSource<T>, Publisher<U>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDelaySubscriptionOtherPublisher
 
MaybeDelayWithCompletable<T> - Class in io.reactivex.internal.operators.maybe
 
MaybeDelayWithCompletable(MaybeSource<T>, CompletableSource) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDelayWithCompletable
 
MaybeDetach<T> - Class in io.reactivex.internal.operators.maybe
Breaks the references between the upstream and downstream when the Maybe terminates.
MaybeDetach(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDetach
 
MaybeDoAfterSuccess<T> - Class in io.reactivex.internal.operators.maybe
Calls a consumer after pushing the current item to the downstream.
MaybeDoAfterSuccess(MaybeSource<T>, Consumer<? super T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDoAfterSuccess
 
MaybeDoFinally<T> - Class in io.reactivex.internal.operators.maybe
Execute an action after an onSuccess, onError, onComplete or a dispose event.
MaybeDoFinally(MaybeSource<T>, Action) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDoFinally
 
MaybeDoOnEvent<T> - Class in io.reactivex.internal.operators.maybe
Calls a BiConsumer with the success, error values of the upstream Maybe or with two nulls if the Maybe completed.
MaybeDoOnEvent(MaybeSource<T>, BiConsumer<? super T, ? super Throwable>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeDoOnEvent
 
MaybeEmitter<T> - Interface in io.reactivex
Abstraction over an RxJava MaybeObserver that allows associating a resource with it.
MaybeEmpty - Class in io.reactivex.internal.operators.maybe
Signals an onComplete.
MaybeEmpty() - Constructor for class io.reactivex.internal.operators.maybe.MaybeEmpty
 
MaybeEqualSingle<T> - Class in io.reactivex.internal.operators.maybe
Compares two MaybeSources to see if they are both empty or emit the same value compared via a BiPredicate.
MaybeEqualSingle(MaybeSource<? extends T>, MaybeSource<? extends T>, BiPredicate<? super T, ? super T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeEqualSingle
 
MaybeError<T> - Class in io.reactivex.internal.operators.maybe
Signals a constant Throwable.
MaybeError(Throwable) - Constructor for class io.reactivex.internal.operators.maybe.MaybeError
 
MaybeErrorCallable<T> - Class in io.reactivex.internal.operators.maybe
Signals a Throwable returned by a Callable.
MaybeErrorCallable(Callable<? extends Throwable>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeErrorCallable
 
MaybeFilter<T> - Class in io.reactivex.internal.operators.maybe
Filters the upstream via a predicate, returning the success item or completing if the predicate returns false.
MaybeFilter(MaybeSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFilter
 
MaybeFilterSingle<T> - Class in io.reactivex.internal.operators.maybe
Filters the upstream SingleSource via a predicate, returning the success item or completing if the predicate returns false.
MaybeFilterSingle(SingleSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFilterSingle
 
MaybeFlatMapBiSelector<T,U,R> - Class in io.reactivex.internal.operators.maybe
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(MaybeSource<T>, Function<? super T, ? extends MaybeSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFlatMapBiSelector
 
MaybeFlatMapCompletable<T> - Class in io.reactivex.internal.operators.maybe
Maps the success value of the source MaybeSource into a Completable.
MaybeFlatMapCompletable(MaybeSource<T>, Function<? super T, ? extends CompletableSource>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFlatMapCompletable
 
MaybeFlatMapIterableFlowable<T,R> - Class in io.reactivex.internal.operators.maybe
Maps a success value into an Iterable and streams it back as a Flowable.
MaybeFlatMapIterableFlowable(MaybeSource<T>, Function<? super T, ? extends Iterable<? extends R>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFlatMapIterableFlowable
 
MaybeFlatMapIterableObservable<T,R> - Class in io.reactivex.internal.operators.maybe
Maps a success value into an Iterable and streams it back as a Flowable.
MaybeFlatMapIterableObservable(MaybeSource<T>, Function<? super T, ? extends Iterable<? extends R>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFlatMapIterableObservable
 
MaybeFlatMapNotification<T,R> - Class in io.reactivex.internal.operators.maybe
Maps a value into a MaybeSource and relays its signal.
MaybeFlatMapNotification(MaybeSource<T>, Function<? super T, ? extends MaybeSource<? extends R>>, Function<? super Throwable, ? extends MaybeSource<? extends R>>, Callable<? extends MaybeSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFlatMapNotification
 
MaybeFlatMapObservable<T,R> - Class in io.reactivex.internal.operators.mixed
Maps the success value of a Maybe onto an ObservableSource and relays its signals to the downstream observer.
MaybeFlatMapObservable(MaybeSource<T>, Function<? super T, ? extends ObservableSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.mixed.MaybeFlatMapObservable
 
MaybeFlatMapPublisher<T,R> - Class in io.reactivex.internal.operators.mixed
Maps the success value of a Maybe onto a Publisher and relays its signals to the downstream subscriber.
MaybeFlatMapPublisher(MaybeSource<T>, Function<? super T, ? extends Publisher<? extends R>>) - Constructor for class io.reactivex.internal.operators.mixed.MaybeFlatMapPublisher
 
MaybeFlatMapSingle<T,R> - Class in io.reactivex.internal.operators.maybe
Maps the success value of the source MaybeSource into a Single.
MaybeFlatMapSingle(MaybeSource<T>, Function<? super T, ? extends SingleSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFlatMapSingle
 
MaybeFlatMapSingleElement<T,R> - Class in io.reactivex.internal.operators.maybe
Maps the success value of the source MaybeSource into a Single.
MaybeFlatMapSingleElement(MaybeSource<T>, Function<? super T, ? extends SingleSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFlatMapSingleElement
 
MaybeFlatten<T,R> - Class in io.reactivex.internal.operators.maybe
Maps a value into a MaybeSource and relays its signal.
MaybeFlatten(MaybeSource<T>, Function<? super T, ? extends MaybeSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFlatten
 
MaybeFromAction<T> - Class in io.reactivex.internal.operators.maybe
Executes an Action and signals its exception or completes normally.
MaybeFromAction(Action) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFromAction
 
MaybeFromCallable<T> - Class in io.reactivex.internal.operators.maybe
Executes a callable and signals its value as success or signals an exception.
MaybeFromCallable(Callable<? extends T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFromCallable
 
MaybeFromCompletable<T> - Class in io.reactivex.internal.operators.maybe
Wrap a Single into a Maybe.
MaybeFromCompletable(CompletableSource) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFromCompletable
 
MaybeFromFuture<T> - Class in io.reactivex.internal.operators.maybe
Waits until the source Future completes or the wait times out; treats a null result as indication to signal onComplete instead of onSuccess.
MaybeFromFuture(Future<? extends T>, long, TimeUnit) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFromFuture
 
MaybeFromRunnable<T> - Class in io.reactivex.internal.operators.maybe
Executes an Runnable and signals its exception or completes normally.
MaybeFromRunnable(Runnable) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFromRunnable
 
MaybeFromSingle<T> - Class in io.reactivex.internal.operators.maybe
Wrap a Single into a Maybe.
MaybeFromSingle(SingleSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeFromSingle
 
MaybeHide<T> - Class in io.reactivex.internal.operators.maybe
Hides the identity of the upstream Maybe and its Disposable sent through onSubscribe.
MaybeHide(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeHide
 
MaybeIgnoreElement<T> - Class in io.reactivex.internal.operators.maybe
Turns an onSuccess into an onComplete, onError and onComplete is relayed as is.
MaybeIgnoreElement(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeIgnoreElement
 
MaybeIgnoreElementCompletable<T> - Class in io.reactivex.internal.operators.maybe
Turns an onSuccess into an onComplete, onError and onComplete is relayed as is.
MaybeIgnoreElementCompletable(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeIgnoreElementCompletable
 
MaybeIsEmpty<T> - Class in io.reactivex.internal.operators.maybe
Signals true if the source Maybe signals onComplete, signals false if the source Maybe signals onSuccess.
MaybeIsEmpty(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeIsEmpty
 
MaybeIsEmptySingle<T> - Class in io.reactivex.internal.operators.maybe
Signals true if the source Maybe signals onComplete, signals false if the source Maybe signals onSuccess.
MaybeIsEmptySingle(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeIsEmptySingle
 
MaybeJust<T> - Class in io.reactivex.internal.operators.maybe
Signals a constant value.
MaybeJust(T) - Constructor for class io.reactivex.internal.operators.maybe.MaybeJust
 
MaybeLift<T,R> - Class in io.reactivex.internal.operators.maybe
Calls a MaybeOperator for the incoming MaybeObserver.
MaybeLift(MaybeSource<T>, MaybeOperator<? extends R, ? super T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeLift
 
MaybeMap<T,R> - Class in io.reactivex.internal.operators.maybe
Maps the upstream success value into some other value.
MaybeMap(MaybeSource<T>, Function<? super T, ? extends R>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeMap
 
MaybeMergeArray<T> - Class in io.reactivex.internal.operators.maybe
Run all MaybeSources of an array at once and signal their values as they become available.
MaybeMergeArray(MaybeSource<? extends T>[]) - Constructor for class io.reactivex.internal.operators.maybe.MaybeMergeArray
 
MaybeNever - Class in io.reactivex.internal.operators.maybe
Doesn't signal any event other than onSubscribe.
MaybeNever() - Constructor for class io.reactivex.internal.operators.maybe.MaybeNever
 
MaybeObserveOn<T> - Class in io.reactivex.internal.operators.maybe
Signals the onSuccess, onError or onComplete events on a the specific scheduler.
MaybeObserveOn(MaybeSource<T>, Scheduler) - Constructor for class io.reactivex.internal.operators.maybe.MaybeObserveOn
 
MaybeObserver<T> - Interface in io.reactivex
Provides a mechanism for receiving push-based notification of a single value, an error or completion without any value.
MaybeOnErrorComplete<T> - Class in io.reactivex.internal.operators.maybe
Emits an onComplete if the source emits an onError and the predicate returns true for that Throwable.
MaybeOnErrorComplete(MaybeSource<T>, Predicate<? super Throwable>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeOnErrorComplete
 
MaybeOnErrorNext<T> - Class in io.reactivex.internal.operators.maybe
Subscribes to the MaybeSource returned by a function if the main source signals an onError.
MaybeOnErrorNext(MaybeSource<T>, Function<? super Throwable, ? extends MaybeSource<? extends T>>, boolean) - Constructor for class io.reactivex.internal.operators.maybe.MaybeOnErrorNext
 
MaybeOnErrorReturn<T> - Class in io.reactivex.internal.operators.maybe
Returns a value generated via a function if the main source signals an onError.
MaybeOnErrorReturn(MaybeSource<T>, Function<? super Throwable, ? extends T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeOnErrorReturn
 
MaybeOnSubscribe<T> - Interface in io.reactivex
A functional interface that has a subscribe() method that receives an instance of a MaybeEmitter instance that allows pushing an event in a cancellation-safe manner.
MaybeOperator<Downstream,Upstream> - Interface in io.reactivex
Interface to map/wrap a downstream observer to an upstream observer.
MaybePeek<T> - Class in io.reactivex.internal.operators.maybe
Peeks into the lifecycle of a Maybe and MaybeObserver.
MaybePeek(MaybeSource<T>, Consumer<? super Disposable>, Consumer<? super T>, Consumer<? super Throwable>, Action, Action, Action) - Constructor for class io.reactivex.internal.operators.maybe.MaybePeek
 
MaybeSource<T> - Interface in io.reactivex
Represents a basic Maybe source base interface, consumable via an MaybeObserver.
MaybeSubject<T> - Class in io.reactivex.subjects
Represents a hot Maybe-like source and consumer of events similar to Subjects.
MaybeSubscribeOn<T> - Class in io.reactivex.internal.operators.maybe
Subscribes to the upstream MaybeSource on the specified scheduler.
MaybeSubscribeOn(MaybeSource<T>, Scheduler) - Constructor for class io.reactivex.internal.operators.maybe.MaybeSubscribeOn
 
MaybeSwitchIfEmpty<T> - Class in io.reactivex.internal.operators.maybe
Subscribes to the other source if the main source is empty.
MaybeSwitchIfEmpty(MaybeSource<T>, MaybeSource<? extends T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeSwitchIfEmpty
 
MaybeSwitchIfEmptySingle<T> - Class in io.reactivex.internal.operators.maybe
Subscribes to the other source if the main source is empty.
MaybeSwitchIfEmptySingle(MaybeSource<T>, SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeSwitchIfEmptySingle
 
MaybeTakeUntilMaybe<T,U> - Class in io.reactivex.internal.operators.maybe
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(MaybeSource<T>, MaybeSource<U>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeTakeUntilMaybe
 
MaybeTakeUntilPublisher<T,U> - Class in io.reactivex.internal.operators.maybe
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(MaybeSource<T>, Publisher<U>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeTakeUntilPublisher
 
MaybeTimeoutMaybe<T,U> - Class in io.reactivex.internal.operators.maybe
Switches to the fallback Maybe if the other MaybeSource signals a success or completes, or signals TimeoutException if fallback is null.
MaybeTimeoutMaybe(MaybeSource<T>, MaybeSource<U>, MaybeSource<? extends T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeTimeoutMaybe
 
MaybeTimeoutPublisher<T,U> - Class in io.reactivex.internal.operators.maybe
Switches to the fallback Maybe if the other Publisher signals a success or completes, or signals TimeoutException if fallback is null.
MaybeTimeoutPublisher(MaybeSource<T>, Publisher<U>, MaybeSource<? extends T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeTimeoutPublisher
 
MaybeTimer - Class in io.reactivex.internal.operators.maybe
Signals a 0L after the specified delay.
MaybeTimer(long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.maybe.MaybeTimer
 
MaybeToFlowable<T> - Class in io.reactivex.internal.operators.maybe
Wraps a MaybeSource and exposes it as a Flowable, relaying signals in a backpressure-aware manner and composes cancellation through.
MaybeToFlowable(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeToFlowable
 
MaybeToObservable<T> - Class in io.reactivex.internal.operators.maybe
Wraps a MaybeSource and exposes it as an Observable, relaying signals in a backpressure-aware manner and composes cancellation through.
MaybeToObservable(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeToObservable
 
MaybeToPublisher - Enum in io.reactivex.internal.operators.maybe
Helper function to merge/concat values of each MaybeSource provided by a Publisher.
MaybeToSingle<T> - Class in io.reactivex.internal.operators.maybe
Wraps a MaybeSource and exposes its onSuccess and onError signals and signals NoSuchElementException for onComplete.
MaybeToSingle(MaybeSource<T>, T) - Constructor for class io.reactivex.internal.operators.maybe.MaybeToSingle
 
MaybeTransformer<Upstream,Downstream> - Interface in io.reactivex
Interface to compose Maybes.
MaybeUnsafeCreate<T> - Class in io.reactivex.internal.operators.maybe
Wraps a MaybeSource without safeguard and calls its subscribe() method for each MaybeObserver.
MaybeUnsafeCreate(MaybeSource<T>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeUnsafeCreate
 
MaybeUnsubscribeOn<T> - Class in io.reactivex.internal.operators.maybe
Makes sure a dispose() call from downstream happens on the specified scheduler.
MaybeUnsubscribeOn(MaybeSource<T>, Scheduler) - Constructor for class io.reactivex.internal.operators.maybe.MaybeUnsubscribeOn
 
MaybeUsing<T,D> - Class in io.reactivex.internal.operators.maybe
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(Callable<? extends D>, Function<? super D, ? extends MaybeSource<? extends T>>, Consumer<? super D>, boolean) - Constructor for class io.reactivex.internal.operators.maybe.MaybeUsing
 
MaybeZipArray<T,R> - Class in io.reactivex.internal.operators.maybe
 
MaybeZipArray(MaybeSource<? extends T>[], Function<? super Object[], ? extends R>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeZipArray
 
MaybeZipIterable<T,R> - Class in io.reactivex.internal.operators.maybe
 
MaybeZipIterable(Iterable<? extends MaybeSource<? extends T>>, Function<? super Object[], ? extends R>) - Constructor for class io.reactivex.internal.operators.maybe.MaybeZipIterable
 
merge(Iterable<? extends CompletableSource>) - Static method in class io.reactivex.Completable
Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.
merge(Publisher<? extends CompletableSource>) - Static method in class io.reactivex.Completable
Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.
merge(Publisher<? extends CompletableSource>, int) - Static method in class io.reactivex.Completable
Returns a Completable instance that keeps subscriptions to a limited number of sources at once and completes only when all source Completables complete or one of them emits an error.
merge(Iterable<? extends Publisher<? extends T>>, int, int) - Static method in class io.reactivex.Flowable
Flattens an Iterable of Publishers into one Publisher, without any transformation, while limiting the number of concurrent subscriptions to these Publishers.
merge(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Flattens an Iterable of Publishers into one Publisher, without any transformation.
merge(Iterable<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.Flowable
Flattens an Iterable of Publishers into one Publisher, without any transformation, while limiting the number of concurrent subscriptions to these Publishers.
merge(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Flattens a Publisher that emits Publishers into a single Publisher that emits the items emitted by those Publishers, without any transformation.
merge(Publisher<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.Flowable
Flattens a Publisher that emits Publishers into a single Publisher that emits the items emitted by those Publishers, without any transformation, while limiting the maximum number of concurrent subscriptions to these Publishers.
merge(Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Flattens two Publishers into a single Publisher, without any transformation.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Flattens three Publishers into a single Publisher, without any transformation.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Flattens four Publishers into a single Publisher, without any transformation.
merge(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Merges an Iterable sequence of MaybeSource instances into a single Flowable sequence, running all MaybeSources at once.
merge(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Merges a Flowable sequence of MaybeSource instances into a single Flowable sequence, running all MaybeSources at once.
merge(Publisher<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.Maybe
Merges a Flowable sequence of MaybeSource instances into a single Flowable sequence, running at most maxConcurrency MaybeSources at once.
merge(MaybeSource<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Flattens a MaybeSource that emits a MaybeSource into a single MaybeSource that emits the item emitted by the nested MaybeSource, without any transformation.
merge(MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Flattens two MaybeSources into a single Flowable, without any transformation.
merge(MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Flattens three MaybeSources into a single Flowable, without any transformation.
merge(MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Flattens four MaybeSources into a single Flowable, without any transformation.
merge(Iterable<? extends ObservableSource<? extends T>>, int, int) - Static method in class io.reactivex.Observable
Flattens an Iterable of ObservableSources into one ObservableSource, without any transformation, while limiting the number of concurrent subscriptions to these ObservableSources.
merge(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Flattens an Iterable of ObservableSources into one ObservableSource, without any transformation.
merge(Iterable<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.Observable
Flattens an Iterable of ObservableSources into one ObservableSource, without any transformation, while limiting the number of concurrent subscriptions to these ObservableSources.
merge(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Flattens an ObservableSource that emits ObservableSources into a single ObservableSource that emits the items emitted by those ObservableSources, without any transformation.
merge(ObservableSource<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.Observable
Flattens an ObservableSource that emits ObservableSources into a single ObservableSource that emits the items emitted by those ObservableSources, without any transformation, while limiting the maximum number of concurrent subscriptions to these ObservableSources.
merge(ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Flattens two ObservableSources into a single ObservableSource, without any transformation.
merge(ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Flattens three ObservableSources into a single ObservableSource, without any transformation.
merge(ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Flattens four ObservableSources into a single ObservableSource, without any transformation.
merge(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Merges an Iterable sequence of SingleSource instances into a single Flowable sequence, running all SingleSources at once.
merge(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Merges a Flowable sequence of SingleSource instances into a single Flowable sequence, running all SingleSources at once.
merge(SingleSource<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Flattens a Single that emits a Single into a single Single that emits the item emitted by the nested Single, without any transformation.
merge(SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Flattens two Singles into a single Flowable, without any transformation.
merge(SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Flattens three Singles into a single Flowable, without any transformation.
merge(SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Flattens four Singles into a single Flowable, without any transformation.
mergeArray(CompletableSource...) - Static method in class io.reactivex.Completable
Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.
mergeArray(int, int, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Flattens an Iterable of Publishers into one Publisher, without any transformation, while limiting the number of concurrent subscriptions to these Publishers.
mergeArray(Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Flattens an Array of Publishers into one Publisher, without any transformation.
mergeArray(MaybeSource<? extends T>...) - Static method in class io.reactivex.Maybe
Merges an array sequence of MaybeSource instances into a single Flowable sequence, running all MaybeSources at once.
mergeArray(int, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Flattens an Iterable of ObservableSources into one ObservableSource, without any transformation, while limiting the number of concurrent subscriptions to these ObservableSources.
mergeArray(ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Flattens an Array of ObservableSources into one ObservableSource, without any transformation.
mergeArrayDelayError(CompletableSource...) - Static method in class io.reactivex.Completable
Returns a CompletableConsumable that subscribes to all Completables in the source array and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.
mergeArrayDelayError(int, int, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Flattens an array of Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from each of the source Publishers without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these Publishers.
mergeArrayDelayError(Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Flattens an array of Publishers into one Flowable, in a way that allows a Subscriber to receive all successfully emitted items from each of the source Publishers without being interrupted by an error notification from one of them.
mergeArrayDelayError(MaybeSource<? extends T>...) - Static method in class io.reactivex.Maybe
Flattens an array of MaybeSources into one Flowable, in a way that allows a Subscriber to receive all successfully emitted items from each of the source MaybeSources without being interrupted by an error notification from one of them.
mergeArrayDelayError(int, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Flattens an array of ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from each of the source ObservableSources without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these ObservableSources.
mergeArrayDelayError(ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Flattens an Iterable of ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from each of the source ObservableSources without being interrupted by an error notification from one of them.
mergeDelayError(Iterable<? extends CompletableSource>) - Static method in class io.reactivex.Completable
Returns a Completable that subscribes to all Completables in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.
mergeDelayError(Publisher<? extends CompletableSource>) - Static method in class io.reactivex.Completable
Returns a Completable that subscribes to all Completables in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.
mergeDelayError(Publisher<? extends CompletableSource>, int) - Static method in class io.reactivex.Completable
Returns a Completable that subscribes to a limited number of inner Completables at once in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.
mergeDelayError(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Flattens an Iterable of Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from each of the source Publishers without being interrupted by an error notification from one of them.
mergeDelayError(Iterable<? extends Publisher<? extends T>>, int, int) - Static method in class io.reactivex.Flowable
Flattens an Iterable of Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from each of the source Publishers without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these Publishers.
mergeDelayError(Iterable<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.Flowable
Flattens an Iterable of Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from each of the source Publishers without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these Publishers.
mergeDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Flattens a Publisher that emits Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from all of the source Publishers without being interrupted by an error notification from one of them.
mergeDelayError(Publisher<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.Flowable
Flattens a Publisher that emits Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from all of the source Publishers without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these Publishers.
mergeDelayError(Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Flattens two Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from each of the source Publishers without being interrupted by an error notification from one of them.
mergeDelayError(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Flattens three Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from all of the source Publishers without being interrupted by an error notification from one of them.
mergeDelayError(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Flattens four Publishers into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from all of the source Publishers without being interrupted by an error notification from one of them.
mergeDelayError(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Flattens an Iterable of MaybeSources into one Flowable, in a way that allows a Subscriber to receive all successfully emitted items from each of the source MaybeSources without being interrupted by an error notification from one of them.
mergeDelayError(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.Maybe
Flattens a Publisher that emits MaybeSources into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from all of the source MaybeSources without being interrupted by an error notification from one of them or even the main Publisher.
mergeDelayError(Publisher<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.Maybe
Flattens a Publisher that emits MaybeSources into one Publisher, in a way that allows a Subscriber to receive all successfully emitted items from all of the source MaybeSources without being interrupted by an error notification from one of them or even the main Publisher as well as limiting the total number of active MaybeSources.
mergeDelayError(MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Flattens two MaybeSources into one Flowable, in a way that allows a Subscriber to receive all successfully emitted items from each of the source MaybeSources without being interrupted by an error notification from one of them.
mergeDelayError(MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Flattens three MaybeSource into one Flowable, in a way that allows a Subscriber to receive all successfully emitted items from all of the source MaybeSources without being interrupted by an error notification from one of them.
mergeDelayError(MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Flattens four MaybeSources into one Flowable, in a way that allows a Subscriber to receive all successfully emitted items from all of the source MaybeSources without being interrupted by an error notification from one of them.
mergeDelayError(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Flattens an Iterable of ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from each of the source ObservableSources without being interrupted by an error notification from one of them.
mergeDelayError(Iterable<? extends ObservableSource<? extends T>>, int, int) - Static method in class io.reactivex.Observable
Flattens an Iterable of ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from each of the source ObservableSources without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these ObservableSources.
mergeDelayError(Iterable<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.Observable
Flattens an Iterable of ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from each of the source ObservableSources without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these ObservableSources.
mergeDelayError(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Flattens an ObservableSource that emits ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from all of the source ObservableSources without being interrupted by an error notification from one of them.
mergeDelayError(ObservableSource<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.Observable
Flattens an ObservableSource that emits ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from all of the source ObservableSources without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these ObservableSources.
mergeDelayError(ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Flattens two ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from each of the source ObservableSources without being interrupted by an error notification from one of them.
mergeDelayError(ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Flattens three ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from all of the source ObservableSources without being interrupted by an error notification from one of them.
mergeDelayError(ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Flattens four ObservableSources into one ObservableSource, in a way that allows an Observer to receive all successfully emitted items from all of the source ObservableSources without being interrupted by an error notification from one of them.
mergeDelayError(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Merges an Iterable sequence of SingleSource instances into a single Flowable sequence, running all SingleSources at once and delaying any error(s) until all sources succeed or fail.
mergeDelayError(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.Single
Merges a Flowable sequence of SingleSource instances into a single Flowable sequence, running all SingleSources at once and delaying any error(s) until all sources succeed or fail.
mergeDelayError(SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Flattens two Singles into a single Flowable, without any transformation, delaying any error(s) until all sources succeed or fail.
mergeDelayError(SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Flattens three Singles into a single Flowable, without any transformation, delaying any error(s) until all sources succeed or fail.
mergeDelayError(SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.Single
Flattens four Singles into a single Flowable, without any transformation, delaying any error(s) until all sources succeed or fail.
MergerBiFunction<T> - Class in io.reactivex.internal.util
A BiFunction that merges two Lists into a new list.
MergerBiFunction(Comparator<? super T>) - Constructor for class io.reactivex.internal.util.MergerBiFunction
 
mergeWith(CompletableSource) - Method in class io.reactivex.Completable
Returns a Completable which subscribes to this and the other Completable and completes when both of them complete or one emits an error.
mergeWith(Publisher<? extends T>) - Method in class io.reactivex.Flowable
Flattens this and another Publisher into a single Publisher, without any transformation.
mergeWith(SingleSource<? extends T>) - Method in class io.reactivex.Flowable
Merges the sequence of items of this Flowable with the success value of the other SingleSource.
mergeWith(MaybeSource<? extends T>) - Method in class io.reactivex.Flowable
Merges the sequence of items of this Flowable with the success value of the other MaybeSource or waits for both to complete normally if the MaybeSource is empty.
mergeWith(CompletableSource) - Method in class io.reactivex.Flowable
Relays the items of this Flowable and completes only when the other CompletableSource completes as well.
mergeWith(MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Flattens this and another Maybe into a single Flowable, without any transformation.
mergeWith(ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Flattens this and another ObservableSource into a single ObservableSource, without any transformation.
mergeWith(SingleSource<? extends T>) - Method in class io.reactivex.Observable
Merges the sequence of items of this Observable with the success value of the other SingleSource.
mergeWith(MaybeSource<? extends T>) - Method in class io.reactivex.Observable
Merges the sequence of items of this Observable with the success value of the other MaybeSource or waits both to complete normally if the MaybeSource is empty.
mergeWith(CompletableSource) - Method in class io.reactivex.Observable
Relays the items of this Observable and completes only when the other CompletableSource completes as well.
mergeWith(SingleSource<? extends T>) - Method in class io.reactivex.Single
Flattens this and another Single into a single Flowable, without any transformation.
MissingBackpressureException - Exception in io.reactivex.exceptions
Indicates that an operator attempted to emit a value but the downstream wasn't ready for it.
MissingBackpressureException() - Constructor for exception io.reactivex.exceptions.MissingBackpressureException
Constructs a MissingBackpressureException without message or cause.
MissingBackpressureException(String) - Constructor for exception io.reactivex.exceptions.MissingBackpressureException
Constructs a MissingBackpressureException with the given message but no cause.
MpscLinkedQueue<T> - Class in io.reactivex.internal.queue
A multi-producer single consumer unbounded queue.
MpscLinkedQueue() - Constructor for class io.reactivex.internal.queue.MpscLinkedQueue
 
MulticastProcessor<T> - Class in io.reactivex.processors
A FlowableProcessor implementation that coordinates downstream requests through a front-buffer and stable-prefetching, optionally canceling the upstream if all subscribers have cancelled.
multicastSelector(Callable<? extends ConnectableFlowable<U>>, Function<? super Flowable<U>, ? extends Publisher<R>>) - Static method in class io.reactivex.internal.operators.flowable.FlowableReplay
Given a connectable observable factory, it multicasts over the generated ConnectableObservable via a selector function.
multicastSelector(Callable<? extends ConnectableObservable<U>>, Function<? super Observable<U>, ? extends ObservableSource<R>>) - Static method in class io.reactivex.internal.operators.observable.ObservableReplay
Given a connectable observable factory, it multicasts over the generated ConnectableObservable via a selector function.
multiplyCap(long, long) - Static method in class io.reactivex.internal.util.BackpressureHelper
Multiplies two long values and caps the product at Long.MAX_VALUE.

N

naturalComparator() - Static method in class io.reactivex.internal.functions.Functions
 
naturalOrder() - Static method in class io.reactivex.internal.functions.Functions
Returns a natural order comparator which casts the parameters to Comparable.
never() - Static method in class io.reactivex.Completable
Returns a Completable that never calls onError or onComplete.
never() - Static method in class io.reactivex.Flowable
Returns a Flowable that never sends any items or notifications to a Subscriber.
never() - Static method in class io.reactivex.Maybe
Returns a Maybe that never sends any items or notifications to a MaybeObserver.
never() - Static method in class io.reactivex.Observable
Returns an Observable that never sends any items or notifications to an Observer.
never() - Static method in class io.reactivex.Single
Returns a singleton instance of a never-signalling Single (only calls onSubscribe).
NEW_THREAD - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
The operator/class runs on RxJava's new thread scheduler or takes timing information from it.
newThread(Runnable) - Method in class io.reactivex.internal.schedulers.RxThreadFactory
 
newThread() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, shared Scheduler instance that creates a new Thread for each unit of work.
NewThreadScheduler - Class in io.reactivex.internal.schedulers
Schedules work on a new thread.
NewThreadScheduler() - Constructor for class io.reactivex.internal.schedulers.NewThreadScheduler
 
NewThreadScheduler(ThreadFactory) - Constructor for class io.reactivex.internal.schedulers.NewThreadScheduler
 
NewThreadWorker - Class in io.reactivex.internal.schedulers
Base class that manages a single-threaded ScheduledExecutorService as a worker but doesn't perform task-tracking operations.
NewThreadWorker(ThreadFactory) - Constructor for class io.reactivex.internal.schedulers.NewThreadWorker
 
next(T) - Static method in enum io.reactivex.internal.util.NotificationLite
Converts a value into a notification value.
NonBlockingThread - Interface in io.reactivex.internal.schedulers
Marker interface to indicate blocking is not recommended while running on a Scheduler with a thread type implementing it.
NONE - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
A special value indicating the operator/class doesn't use schedulers.
NONE - Static variable in interface io.reactivex.internal.fuseable.QueueFuseable
Returned by the QueueFuseable.requestFusion(int) if the upstream doesn't support the requested mode.
NonNull - Annotation Type in io.reactivex.annotations
Indicates that a field/parameter/variable/return type is never null.
Notification<T> - Class in io.reactivex
Represents the reactive signal types: onNext, onError and onComplete and holds their parameter values (a value, a Throwable, nothing).
NotificationLite - Enum in io.reactivex.internal.util
Lightweight notification handling utility class.
notificationOnComplete(Consumer<? super Notification<T>>) - Static method in class io.reactivex.internal.functions.Functions
 
notificationOnError(Consumer<? super Notification<T>>) - Static method in class io.reactivex.internal.functions.Functions
 
notificationOnNext(Consumer<? super Notification<T>>) - Static method in class io.reactivex.internal.functions.Functions
 
now(TimeUnit) - Method in class io.reactivex.Scheduler
Returns the 'current time' of the Scheduler in the specified time unit.
now(TimeUnit) - Method in class io.reactivex.Scheduler.Worker
Returns the 'current time' of the Worker in the specified time unit.
now(TimeUnit) - Method in class io.reactivex.schedulers.TestScheduler
 
Nullable - Annotation Type in io.reactivex.annotations
Indicates that a field/parameter/variable/return type may be null.
nullSupplier() - Static method in class io.reactivex.internal.functions.Functions
 

O

ObjectHelper - Class in io.reactivex.internal.functions
Utility methods containing the backport of Java 7's Objects utility class.
Observable<T> - Class in io.reactivex
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.
Observable() - Constructor for class io.reactivex.Observable
 
ObservableAll<T> - Class in io.reactivex.internal.operators.observable
 
ObservableAll(ObservableSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableAll
 
ObservableAllSingle<T> - Class in io.reactivex.internal.operators.observable
 
ObservableAllSingle(ObservableSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableAllSingle
 
ObservableAmb<T> - Class in io.reactivex.internal.operators.observable
 
ObservableAmb(ObservableSource<? extends T>[], Iterable<? extends ObservableSource<? extends T>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableAmb
 
ObservableAny<T> - Class in io.reactivex.internal.operators.observable
 
ObservableAny(ObservableSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableAny
 
ObservableAnySingle<T> - Class in io.reactivex.internal.operators.observable
 
ObservableAnySingle(ObservableSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableAnySingle
 
ObservableAutoConnect<T> - Class in io.reactivex.internal.operators.observable
Wraps a ConnectableObservable and calls its connect() method once the specified number of Observers have subscribed.
ObservableAutoConnect(ConnectableObservable<? extends T>, int, Consumer<? super Disposable>) - Constructor for class io.reactivex.internal.operators.observable.ObservableAutoConnect
 
ObservableBlockingSubscribe - Class in io.reactivex.internal.operators.observable
Utility methods to consume an Observable in a blocking manner with callbacks or Observer.
ObservableBuffer<T,U extends Collection<? super T>> - Class in io.reactivex.internal.operators.observable
 
ObservableBuffer(ObservableSource<T>, int, int, Callable<U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableBuffer
 
ObservableBufferBoundary<T,U extends Collection<? super T>,Open,Close> - Class in io.reactivex.internal.operators.observable
 
ObservableBufferBoundary(ObservableSource<T>, ObservableSource<? extends Open>, Function<? super Open, ? extends ObservableSource<? extends Close>>, Callable<U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableBufferBoundary
 
ObservableBufferBoundarySupplier<T,U extends Collection<? super T>,B> - Class in io.reactivex.internal.operators.observable
 
ObservableBufferBoundarySupplier(ObservableSource<T>, Callable<? extends ObservableSource<B>>, Callable<U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableBufferBoundarySupplier
 
ObservableBufferExactBoundary<T,U extends Collection<? super T>,B> - Class in io.reactivex.internal.operators.observable
 
ObservableBufferExactBoundary(ObservableSource<T>, ObservableSource<B>, Callable<U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableBufferExactBoundary
 
ObservableBufferTimed<T,U extends Collection<? super T>> - Class in io.reactivex.internal.operators.observable
 
ObservableBufferTimed(ObservableSource<T>, long, long, TimeUnit, Scheduler, Callable<U>, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableBufferTimed
 
ObservableCache<T> - Class in io.reactivex.internal.operators.observable
An observable which auto-connects to another observable, caches the elements from that observable but allows terminating the connection and completing the cache.
ObservableCollect<T,U> - Class in io.reactivex.internal.operators.observable
 
ObservableCollect(ObservableSource<T>, Callable<? extends U>, BiConsumer<? super U, ? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableCollect
 
ObservableCollectSingle<T,U> - Class in io.reactivex.internal.operators.observable
 
ObservableCollectSingle(ObservableSource<T>, Callable<? extends U>, BiConsumer<? super U, ? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableCollectSingle
 
ObservableCombineLatest<T,R> - Class in io.reactivex.internal.operators.observable
 
ObservableCombineLatest(ObservableSource<? extends T>[], Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableCombineLatest
 
ObservableConcatMap<T,U> - Class in io.reactivex.internal.operators.observable
 
ObservableConcatMap(ObservableSource<T>, Function<? super T, ? extends ObservableSource<? extends U>>, int, ErrorMode) - Constructor for class io.reactivex.internal.operators.observable.ObservableConcatMap
 
ObservableConcatMapCompletable<T> - Class in io.reactivex.internal.operators.mixed
Maps the upstream items into CompletableSources and subscribes to them one after the other completes or terminates (in error-delaying mode).
ObservableConcatMapCompletable(Observable<T>, Function<? super T, ? extends CompletableSource>, ErrorMode, int) - Constructor for class io.reactivex.internal.operators.mixed.ObservableConcatMapCompletable
 
ObservableConcatMapEager<T,R> - Class in io.reactivex.internal.operators.observable
 
ObservableConcatMapEager(ObservableSource<T>, Function<? super T, ? extends ObservableSource<? extends R>>, ErrorMode, int, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableConcatMapEager
 
ObservableConcatMapMaybe<T,R> - Class in io.reactivex.internal.operators.mixed
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(Observable<T>, Function<? super T, ? extends MaybeSource<? extends R>>, ErrorMode, int) - Constructor for class io.reactivex.internal.operators.mixed.ObservableConcatMapMaybe
 
ObservableConcatMapSingle<T,R> - Class in io.reactivex.internal.operators.mixed
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(Observable<T>, Function<? super T, ? extends SingleSource<? extends R>>, ErrorMode, int) - Constructor for class io.reactivex.internal.operators.mixed.ObservableConcatMapSingle
 
ObservableConcatWithCompletable<T> - Class in io.reactivex.internal.operators.observable
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(Observable<T>, CompletableSource) - Constructor for class io.reactivex.internal.operators.observable.ObservableConcatWithCompletable
 
ObservableConcatWithMaybe<T> - Class in io.reactivex.internal.operators.observable
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(Observable<T>, MaybeSource<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableConcatWithMaybe
 
ObservableConcatWithSingle<T> - Class in io.reactivex.internal.operators.observable
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(Observable<T>, SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableConcatWithSingle
 
ObservableConverter<T,R> - Interface in io.reactivex
Convenience interface and callback used by the Observable.as(io.reactivex.ObservableConverter<T, ? extends R>) operator to turn an Observable into another value fluently.
ObservableCount<T> - Class in io.reactivex.internal.operators.observable
 
ObservableCount(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableCount
 
ObservableCountSingle<T> - Class in io.reactivex.internal.operators.observable
 
ObservableCountSingle(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableCountSingle
 
ObservableCreate<T> - Class in io.reactivex.internal.operators.observable
 
ObservableCreate(ObservableOnSubscribe<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableCreate
 
ObservableDebounce<T,U> - Class in io.reactivex.internal.operators.observable
 
ObservableDebounce(ObservableSource<T>, Function<? super T, ? extends ObservableSource<U>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableDebounce
 
ObservableDebounceTimed<T> - Class in io.reactivex.internal.operators.observable
 
ObservableDebounceTimed(ObservableSource<T>, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableDebounceTimed
 
ObservableDefer<T> - Class in io.reactivex.internal.operators.observable
 
ObservableDefer(Callable<? extends ObservableSource<? extends T>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableDefer
 
ObservableDelay<T> - Class in io.reactivex.internal.operators.observable
 
ObservableDelay(ObservableSource<T>, long, TimeUnit, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableDelay
 
ObservableDelaySubscriptionOther<T,U> - Class in io.reactivex.internal.operators.observable
Delays the subscription to the main source until the other observable fires an event or completes.
ObservableDelaySubscriptionOther(ObservableSource<? extends T>, ObservableSource<U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableDelaySubscriptionOther
 
ObservableDematerialize<T> - Class in io.reactivex.internal.operators.observable
 
ObservableDematerialize(ObservableSource<Notification<T>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableDematerialize
 
ObservableDetach<T> - Class in io.reactivex.internal.operators.observable
Breaks the links between the upstream and the downstream (the Disposable and the Observer references) when the sequence terminates or gets disposed.
ObservableDetach(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableDetach
 
ObservableDistinct<T,K> - Class in io.reactivex.internal.operators.observable
 
ObservableDistinct(ObservableSource<T>, Function<? super T, K>, Callable<? extends Collection<? super K>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableDistinct
 
ObservableDistinctUntilChanged<T,K> - Class in io.reactivex.internal.operators.observable
 
ObservableDistinctUntilChanged(ObservableSource<T>, Function<? super T, K>, BiPredicate<? super K, ? super K>) - Constructor for class io.reactivex.internal.operators.observable.ObservableDistinctUntilChanged
 
ObservableDoAfterNext<T> - Class in io.reactivex.internal.operators.observable
Calls a consumer after pushing the current item to the downstream.
ObservableDoAfterNext(ObservableSource<T>, Consumer<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableDoAfterNext
 
ObservableDoFinally<T> - Class in io.reactivex.internal.operators.observable
Execute an action after an onError, onComplete or a dispose event.
ObservableDoFinally(ObservableSource<T>, Action) - Constructor for class io.reactivex.internal.operators.observable.ObservableDoFinally
 
ObservableDoOnEach<T> - Class in io.reactivex.internal.operators.observable
 
ObservableDoOnEach(ObservableSource<T>, Consumer<? super T>, Consumer<? super Throwable>, Action, Action) - Constructor for class io.reactivex.internal.operators.observable.ObservableDoOnEach
 
ObservableDoOnLifecycle<T> - Class in io.reactivex.internal.operators.observable
 
ObservableDoOnLifecycle(Observable<T>, Consumer<? super Disposable>, Action) - Constructor for class io.reactivex.internal.operators.observable.ObservableDoOnLifecycle
 
ObservableElementAt<T> - Class in io.reactivex.internal.operators.observable
 
ObservableElementAt(ObservableSource<T>, long, T, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableElementAt
 
ObservableElementAtMaybe<T> - Class in io.reactivex.internal.operators.observable
 
ObservableElementAtMaybe(ObservableSource<T>, long) - Constructor for class io.reactivex.internal.operators.observable.ObservableElementAtMaybe
 
ObservableElementAtSingle<T> - Class in io.reactivex.internal.operators.observable
 
ObservableElementAtSingle(ObservableSource<T>, long, T) - Constructor for class io.reactivex.internal.operators.observable.ObservableElementAtSingle
 
ObservableEmitter<T> - Interface in io.reactivex
Abstraction over an RxJava Observer that allows associating a resource with it.
ObservableEmpty - Class in io.reactivex.internal.operators.observable
 
ObservableError<T> - Class in io.reactivex.internal.operators.observable
 
ObservableError(Callable<? extends Throwable>) - Constructor for class io.reactivex.internal.operators.observable.ObservableError
 
ObservableFilter<T> - Class in io.reactivex.internal.operators.observable
 
ObservableFilter(ObservableSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableFilter
 
ObservableFlatMap<T,U> - Class in io.reactivex.internal.operators.observable
 
ObservableFlatMap(ObservableSource<T>, Function<? super T, ? extends ObservableSource<? extends U>>, boolean, int, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableFlatMap
 
ObservableFlatMapCompletable<T> - Class in io.reactivex.internal.operators.observable
Maps a sequence of values into CompletableSources and awaits their termination.
ObservableFlatMapCompletable(ObservableSource<T>, Function<? super T, ? extends CompletableSource>, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableFlatMapCompletable
 
ObservableFlatMapCompletableCompletable<T> - Class in io.reactivex.internal.operators.observable
Maps a sequence of values into CompletableSources and awaits their termination.
ObservableFlatMapCompletableCompletable(ObservableSource<T>, Function<? super T, ? extends CompletableSource>, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableFlatMapCompletableCompletable
 
ObservableFlatMapMaybe<T,R> - Class in io.reactivex.internal.operators.observable
Maps upstream values into MaybeSources and merges their signals into one sequence.
ObservableFlatMapMaybe(ObservableSource<T>, Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableFlatMapMaybe
 
ObservableFlatMapSingle<T,R> - Class in io.reactivex.internal.operators.observable
Maps upstream values into SingleSources and merges their signals into one sequence.
ObservableFlatMapSingle(ObservableSource<T>, Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableFlatMapSingle
 
ObservableFlattenIterable<T,R> - Class in io.reactivex.internal.operators.observable
Maps a sequence into an Iterable and emits its values.
ObservableFlattenIterable(ObservableSource<T>, Function<? super T, ? extends Iterable<? extends R>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableFlattenIterable
 
ObservableFromArray<T> - Class in io.reactivex.internal.operators.observable
 
ObservableFromArray(T[]) - Constructor for class io.reactivex.internal.operators.observable.ObservableFromArray
 
ObservableFromCallable<T> - Class in io.reactivex.internal.operators.observable
Calls a Callable and emits its resulting single value or signals its exception.
ObservableFromCallable(Callable<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableFromCallable
 
ObservableFromFuture<T> - Class in io.reactivex.internal.operators.observable
 
ObservableFromFuture(Future<? extends T>, long, TimeUnit) - Constructor for class io.reactivex.internal.operators.observable.ObservableFromFuture
 
ObservableFromIterable<T> - Class in io.reactivex.internal.operators.observable
 
ObservableFromIterable(Iterable<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableFromIterable
 
ObservableFromPublisher<T> - Class in io.reactivex.internal.operators.observable
 
ObservableFromPublisher(Publisher<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableFromPublisher
 
ObservableFromUnsafeSource<T> - Class in io.reactivex.internal.operators.observable
 
ObservableFromUnsafeSource(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableFromUnsafeSource
 
ObservableGenerate<T,S> - Class in io.reactivex.internal.operators.observable
 
ObservableGenerate(Callable<S>, BiFunction<S, Emitter<T>, S>, Consumer<? super S>) - Constructor for class io.reactivex.internal.operators.observable.ObservableGenerate
 
ObservableGroupBy<T,K,V> - Class in io.reactivex.internal.operators.observable
 
ObservableGroupBy(ObservableSource<T>, Function<? super T, ? extends K>, Function<? super T, ? extends V>, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableGroupBy
 
ObservableGroupBy.GroupByObserver<T,K,V> - Class in io.reactivex.internal.operators.observable
 
ObservableGroupJoin<TLeft,TRight,TLeftEnd,TRightEnd,R> - Class in io.reactivex.internal.operators.observable
 
ObservableGroupJoin(ObservableSource<TLeft>, ObservableSource<? extends TRight>, Function<? super TLeft, ? extends ObservableSource<TLeftEnd>>, Function<? super TRight, ? extends ObservableSource<TRightEnd>>, BiFunction<? super TLeft, ? super Observable<TRight>, ? extends R>) - Constructor for class io.reactivex.internal.operators.observable.ObservableGroupJoin
 
ObservableHide<T> - Class in io.reactivex.internal.operators.observable
Hides the identity of the wrapped ObservableSource and its Disposable.
ObservableHide(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableHide
 
ObservableIgnoreElements<T> - Class in io.reactivex.internal.operators.observable
 
ObservableIgnoreElements(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableIgnoreElements
 
ObservableIgnoreElementsCompletable<T> - Class in io.reactivex.internal.operators.observable
 
ObservableIgnoreElementsCompletable(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableIgnoreElementsCompletable
 
ObservableInternalHelper - Class in io.reactivex.internal.operators.observable
Helper utility class to support Observable with inner classes.
ObservableInterval - Class in io.reactivex.internal.operators.observable
 
ObservableInterval(long, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableInterval
 
ObservableIntervalRange - Class in io.reactivex.internal.operators.observable
 
ObservableIntervalRange(long, long, long, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableIntervalRange
 
ObservableJoin<TLeft,TRight,TLeftEnd,TRightEnd,R> - Class in io.reactivex.internal.operators.observable
 
ObservableJoin(ObservableSource<TLeft>, ObservableSource<? extends TRight>, Function<? super TLeft, ? extends ObservableSource<TLeftEnd>>, Function<? super TRight, ? extends ObservableSource<TRightEnd>>, BiFunction<? super TLeft, ? super TRight, ? extends R>) - Constructor for class io.reactivex.internal.operators.observable.ObservableJoin
 
ObservableJust<T> - Class in io.reactivex.internal.operators.observable
Represents a constant scalar value.
ObservableJust(T) - Constructor for class io.reactivex.internal.operators.observable.ObservableJust
 
ObservableLastMaybe<T> - Class in io.reactivex.internal.operators.observable
Consumes the source ObservableSource and emits its last item, the defaultItem if empty or a NoSuchElementException if even the defaultItem is null.
ObservableLastMaybe(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableLastMaybe
 
ObservableLastSingle<T> - Class in io.reactivex.internal.operators.observable
Consumes the source ObservableSource and emits its last item, the defaultItem if empty or a NoSuchElementException if even the defaultItem is null.
ObservableLastSingle(ObservableSource<T>, T) - Constructor for class io.reactivex.internal.operators.observable.ObservableLastSingle
 
ObservableLift<R,T> - Class in io.reactivex.internal.operators.observable
Allows lifting operators into a chain of Observables.
ObservableLift(ObservableSource<T>, ObservableOperator<? extends R, ? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableLift
 
ObservableMap<T,U> - Class in io.reactivex.internal.operators.observable
 
ObservableMap(ObservableSource<T>, Function<? super T, ? extends U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableMap
 
ObservableMapNotification<T,R> - Class in io.reactivex.internal.operators.observable
 
ObservableMapNotification(ObservableSource<T>, Function<? super T, ? extends ObservableSource<? extends R>>, Function<? super Throwable, ? extends ObservableSource<? extends R>>, Callable<? extends ObservableSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableMapNotification
 
ObservableMaterialize<T> - Class in io.reactivex.internal.operators.observable
 
ObservableMaterialize(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableMaterialize
 
ObservableMergeWithCompletable<T> - Class in io.reactivex.internal.operators.observable
Merges an Observable and a Completable by emitting the items of the Observable and waiting until both the Observable and Completable complete normally.
ObservableMergeWithCompletable(Observable<T>, CompletableSource) - Constructor for class io.reactivex.internal.operators.observable.ObservableMergeWithCompletable
 
ObservableMergeWithMaybe<T> - Class in io.reactivex.internal.operators.observable
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(Observable<T>, MaybeSource<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableMergeWithMaybe
 
ObservableMergeWithSingle<T> - Class in io.reactivex.internal.operators.observable
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(Observable<T>, SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableMergeWithSingle
 
ObservableNever - Class in io.reactivex.internal.operators.observable
 
ObservableObserveOn<T> - Class in io.reactivex.internal.operators.observable
 
ObservableObserveOn(ObservableSource<T>, Scheduler, boolean, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableObserveOn
 
ObservableOnErrorNext<T> - Class in io.reactivex.internal.operators.observable
 
ObservableOnErrorNext(ObservableSource<T>, Function<? super Throwable, ? extends ObservableSource<? extends T>>, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableOnErrorNext
 
ObservableOnErrorReturn<T> - Class in io.reactivex.internal.operators.observable
 
ObservableOnErrorReturn(ObservableSource<T>, Function<? super Throwable, ? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableOnErrorReturn
 
ObservableOnSubscribe<T> - Interface in io.reactivex
A functional interface that has a subscribe() method that receives an instance of an ObservableEmitter instance that allows pushing events in a cancellation-safe manner.
ObservableOperator<Downstream,Upstream> - Interface in io.reactivex
Interface to map/wrap a downstream observer to an upstream observer.
ObservablePublish<T> - Class in io.reactivex.internal.operators.observable
A connectable observable which shares an underlying source and dispatches source values to observers in a backpressure-aware manner.
ObservablePublishSelector<T,R> - Class in io.reactivex.internal.operators.observable
Shares a source Observable for the duration of a selector function.
ObservablePublishSelector(ObservableSource<T>, Function<? super Observable<T>, ? extends ObservableSource<R>>) - Constructor for class io.reactivex.internal.operators.observable.ObservablePublishSelector
 
ObservableQueueDrain<T,U> - Interface in io.reactivex.internal.util
 
ObservableRange - Class in io.reactivex.internal.operators.observable
Emits a range of integer values from start to end.
ObservableRange(int, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableRange
 
ObservableRangeLong - Class in io.reactivex.internal.operators.observable
 
ObservableRangeLong(long, long) - Constructor for class io.reactivex.internal.operators.observable.ObservableRangeLong
 
ObservableReduceMaybe<T> - Class in io.reactivex.internal.operators.observable
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(ObservableSource<T>, BiFunction<T, T, T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableReduceMaybe
 
ObservableReduceSeedSingle<T,R> - Class in io.reactivex.internal.operators.observable
Reduce a sequence of values, starting from a seed value and by using an accumulator function and return the last accumulated value.
ObservableReduceSeedSingle(ObservableSource<T>, R, BiFunction<R, ? super T, R>) - Constructor for class io.reactivex.internal.operators.observable.ObservableReduceSeedSingle
 
ObservableReduceWithSingle<T,R> - Class in io.reactivex.internal.operators.observable
Reduce a sequence of values, starting from a generated seed value and by using an accumulator function and return the last accumulated value.
ObservableReduceWithSingle(ObservableSource<T>, Callable<R>, BiFunction<R, ? super T, R>) - Constructor for class io.reactivex.internal.operators.observable.ObservableReduceWithSingle
 
ObservableRefCount<T> - Class in io.reactivex.internal.operators.observable
Returns an observable sequence that stays connected to the source as long as there is at least one subscription to the observable sequence.
ObservableRefCount(ConnectableObservable<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableRefCount
 
ObservableRefCount(ConnectableObservable<T>, int, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableRefCount
 
ObservableRepeat<T> - Class in io.reactivex.internal.operators.observable
 
ObservableRepeat(Observable<T>, long) - Constructor for class io.reactivex.internal.operators.observable.ObservableRepeat
 
ObservableRepeatUntil<T> - Class in io.reactivex.internal.operators.observable
 
ObservableRepeatUntil(Observable<T>, BooleanSupplier) - Constructor for class io.reactivex.internal.operators.observable.ObservableRepeatUntil
 
ObservableRepeatWhen<T> - Class in io.reactivex.internal.operators.observable
Repeatedly subscribe to a source if a handler ObservableSource signals an item.
ObservableRepeatWhen(ObservableSource<T>, Function<? super Observable<Object>, ? extends ObservableSource<?>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableRepeatWhen
 
ObservableReplay<T> - Class in io.reactivex.internal.operators.observable
 
ObservableRetryBiPredicate<T> - Class in io.reactivex.internal.operators.observable
 
ObservableRetryBiPredicate(Observable<T>, BiPredicate<? super Integer, ? super Throwable>) - Constructor for class io.reactivex.internal.operators.observable.ObservableRetryBiPredicate
 
ObservableRetryPredicate<T> - Class in io.reactivex.internal.operators.observable
 
ObservableRetryPredicate(Observable<T>, long, Predicate<? super Throwable>) - Constructor for class io.reactivex.internal.operators.observable.ObservableRetryPredicate
 
ObservableRetryWhen<T> - Class in io.reactivex.internal.operators.observable
Repeatedly subscribe to a source if a handler ObservableSource signals an item.
ObservableRetryWhen(ObservableSource<T>, Function<? super Observable<Throwable>, ? extends ObservableSource<?>>) - Constructor for class io.reactivex.internal.operators.observable.ObservableRetryWhen
 
ObservableSampleTimed<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSampleTimed(ObservableSource<T>, long, TimeUnit, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableSampleTimed
 
ObservableSampleWithObservable<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSampleWithObservable(ObservableSource<T>, ObservableSource<?>, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableSampleWithObservable
 
ObservableScalarXMap - Class in io.reactivex.internal.operators.observable
Utility classes to work with scalar-sourced XMap operators (where X == { flat, concat, switch }).
ObservableScalarXMap.ScalarDisposable<T> - Class in io.reactivex.internal.operators.observable
Represents a Disposable that signals one onNext followed by an onComplete.
ObservableScan<T> - Class in io.reactivex.internal.operators.observable
 
ObservableScan(ObservableSource<T>, BiFunction<T, T, T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableScan
 
ObservableScanSeed<T,R> - Class in io.reactivex.internal.operators.observable
 
ObservableScanSeed(ObservableSource<T>, Callable<R>, BiFunction<R, ? super T, R>) - Constructor for class io.reactivex.internal.operators.observable.ObservableScanSeed
 
ObservableSequenceEqual<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>, BiPredicate<? super T, ? super T>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableSequenceEqual
 
ObservableSequenceEqualSingle<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSequenceEqualSingle(ObservableSource<? extends T>, ObservableSource<? extends T>, BiPredicate<? super T, ? super T>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableSequenceEqualSingle
 
ObservableSerialized<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSerialized(Observable<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableSerialized
 
ObservableSingleMaybe<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSingleMaybe(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableSingleMaybe
 
ObservableSingleSingle<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSingleSingle(ObservableSource<? extends T>, T) - Constructor for class io.reactivex.internal.operators.observable.ObservableSingleSingle
 
ObservableSkip<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSkip(ObservableSource<T>, long) - Constructor for class io.reactivex.internal.operators.observable.ObservableSkip
 
ObservableSkipLast<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSkipLast(ObservableSource<T>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableSkipLast
 
ObservableSkipLastTimed<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSkipLastTimed(ObservableSource<T>, long, TimeUnit, Scheduler, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableSkipLastTimed
 
ObservableSkipUntil<T,U> - Class in io.reactivex.internal.operators.observable
 
ObservableSkipUntil(ObservableSource<T>, ObservableSource<U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableSkipUntil
 
ObservableSkipWhile<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSkipWhile(ObservableSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableSkipWhile
 
ObservableSource<T> - Interface in io.reactivex
Represents a basic, non-backpressured Observable source base interface, consumable via an Observer.
ObservableSubscribeOn<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSubscribeOn(ObservableSource<T>, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableSubscribeOn
 
ObservableSwitchIfEmpty<T> - Class in io.reactivex.internal.operators.observable
 
ObservableSwitchIfEmpty(ObservableSource<T>, ObservableSource<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableSwitchIfEmpty
 
ObservableSwitchMap<T,R> - Class in io.reactivex.internal.operators.observable
 
ObservableSwitchMap(ObservableSource<T>, Function<? super T, ? extends ObservableSource<? extends R>>, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableSwitchMap
 
ObservableSwitchMapCompletable<T> - Class in io.reactivex.internal.operators.mixed
Maps the upstream values into CompletableSources, subscribes to the newer one while disposing the subscription to the previous CompletableSource, thus keeping at most one active CompletableSource running.
ObservableSwitchMapCompletable(Observable<T>, Function<? super T, ? extends CompletableSource>, boolean) - Constructor for class io.reactivex.internal.operators.mixed.ObservableSwitchMapCompletable
 
ObservableSwitchMapMaybe<T,R> - Class in io.reactivex.internal.operators.mixed
Maps the upstream items into MaybeSources 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(Observable<T>, Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Constructor for class io.reactivex.internal.operators.mixed.ObservableSwitchMapMaybe
 
ObservableSwitchMapSingle<T,R> - Class in io.reactivex.internal.operators.mixed
Maps the upstream items into SingleSources 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(Observable<T>, Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Constructor for class io.reactivex.internal.operators.mixed.ObservableSwitchMapSingle
 
ObservableTake<T> - Class in io.reactivex.internal.operators.observable
 
ObservableTake(ObservableSource<T>, long) - Constructor for class io.reactivex.internal.operators.observable.ObservableTake
 
ObservableTakeLast<T> - Class in io.reactivex.internal.operators.observable
 
ObservableTakeLast(ObservableSource<T>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableTakeLast
 
ObservableTakeLastOne<T> - Class in io.reactivex.internal.operators.observable
 
ObservableTakeLastOne(ObservableSource<T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableTakeLastOne
 
ObservableTakeLastTimed<T> - Class in io.reactivex.internal.operators.observable
 
ObservableTakeLastTimed(ObservableSource<T>, long, long, TimeUnit, Scheduler, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableTakeLastTimed
 
ObservableTakeUntil<T,U> - Class in io.reactivex.internal.operators.observable
 
ObservableTakeUntil(ObservableSource<T>, ObservableSource<? extends U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableTakeUntil
 
ObservableTakeUntilPredicate<T> - Class in io.reactivex.internal.operators.observable
 
ObservableTakeUntilPredicate(ObservableSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableTakeUntilPredicate
 
ObservableTakeWhile<T> - Class in io.reactivex.internal.operators.observable
 
ObservableTakeWhile(ObservableSource<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableTakeWhile
 
ObservableThrottleFirstTimed<T> - Class in io.reactivex.internal.operators.observable
 
ObservableThrottleFirstTimed(ObservableSource<T>, long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableThrottleFirstTimed
 
ObservableThrottleLatest<T> - Class in io.reactivex.internal.operators.observable
Emits the next or latest item when the given time elapses.
ObservableThrottleLatest(Observable<T>, long, TimeUnit, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableThrottleLatest
 
ObservableTimeInterval<T> - Class in io.reactivex.internal.operators.observable
 
ObservableTimeInterval(ObservableSource<T>, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableTimeInterval
 
ObservableTimeout<T,U,V> - Class in io.reactivex.internal.operators.observable
 
ObservableTimeout(Observable<T>, ObservableSource<U>, Function<? super T, ? extends ObservableSource<V>>, ObservableSource<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableTimeout
 
ObservableTimeoutTimed<T> - Class in io.reactivex.internal.operators.observable
 
ObservableTimeoutTimed(Observable<T>, long, TimeUnit, Scheduler, ObservableSource<? extends T>) - Constructor for class io.reactivex.internal.operators.observable.ObservableTimeoutTimed
 
ObservableTimer - Class in io.reactivex.internal.operators.observable
 
ObservableTimer(long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableTimer
 
ObservableToList<T,U extends Collection<? super T>> - Class in io.reactivex.internal.operators.observable
 
ObservableToList(ObservableSource<T>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableToList
 
ObservableToList(ObservableSource<T>, Callable<U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableToList
 
ObservableToListSingle<T,U extends Collection<? super T>> - Class in io.reactivex.internal.operators.observable
 
ObservableToListSingle(ObservableSource<T>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableToListSingle
 
ObservableToListSingle(ObservableSource<T>, Callable<U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableToListSingle
 
ObservableTransformer<Upstream,Downstream> - Interface in io.reactivex
Interface to compose Observables.
ObservableUnsubscribeOn<T> - Class in io.reactivex.internal.operators.observable
 
ObservableUnsubscribeOn(ObservableSource<T>, Scheduler) - Constructor for class io.reactivex.internal.operators.observable.ObservableUnsubscribeOn
 
ObservableUsing<T,D> - Class in io.reactivex.internal.operators.observable
 
ObservableUsing(Callable<? extends D>, Function<? super D, ? extends ObservableSource<? extends T>>, Consumer<? super D>, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableUsing
 
ObservableWindow<T> - Class in io.reactivex.internal.operators.observable
 
ObservableWindow(ObservableSource<T>, long, long, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableWindow
 
ObservableWindowBoundary<T,B> - Class in io.reactivex.internal.operators.observable
 
ObservableWindowBoundary(ObservableSource<T>, ObservableSource<B>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableWindowBoundary
 
ObservableWindowBoundarySelector<T,B,V> - Class in io.reactivex.internal.operators.observable
 
ObservableWindowBoundarySelector(ObservableSource<T>, ObservableSource<B>, Function<? super B, ? extends ObservableSource<V>>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableWindowBoundarySelector
 
ObservableWindowBoundarySupplier<T,B> - Class in io.reactivex.internal.operators.observable
 
ObservableWindowBoundarySupplier(ObservableSource<T>, Callable<? extends ObservableSource<B>>, int) - Constructor for class io.reactivex.internal.operators.observable.ObservableWindowBoundarySupplier
 
ObservableWindowTimed<T> - Class in io.reactivex.internal.operators.observable
 
ObservableWindowTimed(ObservableSource<T>, long, long, TimeUnit, Scheduler, long, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableWindowTimed
 
ObservableWithLatestFrom<T,U,R> - Class in io.reactivex.internal.operators.observable
 
ObservableWithLatestFrom(ObservableSource<T>, BiFunction<? super T, ? super U, ? extends R>, ObservableSource<? extends U>) - Constructor for class io.reactivex.internal.operators.observable.ObservableWithLatestFrom
 
ObservableWithLatestFromMany<T,R> - Class in io.reactivex.internal.operators.observable
Combines a main sequence of values with the latest from multiple other sequences via a selector function.
ObservableWithLatestFromMany(ObservableSource<T>, ObservableSource<?>[], Function<? super Object[], R>) - Constructor for class io.reactivex.internal.operators.observable.ObservableWithLatestFromMany
 
ObservableWithLatestFromMany(ObservableSource<T>, Iterable<? extends ObservableSource<?>>, Function<? super Object[], R>) - Constructor for class io.reactivex.internal.operators.observable.ObservableWithLatestFromMany
 
ObservableZip<T,R> - Class in io.reactivex.internal.operators.observable
 
ObservableZip(ObservableSource<? extends T>[], Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>, int, boolean) - Constructor for class io.reactivex.internal.operators.observable.ObservableZip
 
ObservableZipIterable<T,U,V> - Class in io.reactivex.internal.operators.observable
 
ObservableZipIterable(Observable<? extends T>, Iterable<U>, BiFunction<? super T, ? super U, ? extends V>) - Constructor for class io.reactivex.internal.operators.observable.ObservableZipIterable
 
observeOn(Scheduler) - Method in class io.reactivex.Completable
Returns a Completable which emits the terminal events from the thread of the specified scheduler.
observeOn(Scheduler) - Method in class io.reactivex.Flowable
Modifies a Publisher to perform its emissions and notifications on a specified Scheduler, asynchronously with a bounded buffer of Flowable.bufferSize() slots.
observeOn(Scheduler, boolean) - Method in class io.reactivex.Flowable
Modifies a Publisher to perform its emissions and notifications on a specified Scheduler, asynchronously with a bounded buffer and optionally delays onError notifications.
observeOn(Scheduler, boolean, int) - Method in class io.reactivex.Flowable
Modifies a Publisher to perform its emissions and notifications on a specified Scheduler, asynchronously with a bounded buffer of configurable size and optionally delays onError notifications.
observeOn(ConnectableFlowable<T>, Scheduler) - Static method in class io.reactivex.internal.operators.flowable.FlowableReplay
Child Subscribers will observe the events of the ConnectableObservable on the specified scheduler.
observeOn(ConnectableObservable<T>, Scheduler) - Static method in class io.reactivex.internal.operators.observable.ObservableReplay
Child Observers will observe the events of the ConnectableObservable on the specified scheduler.
observeOn(Scheduler) - Method in class io.reactivex.Maybe
Wraps a Maybe to emit its item (or notify of its error) on a specified Scheduler, asynchronously.
observeOn(Scheduler) - Method in class io.reactivex.Observable
Modifies an ObservableSource to perform its emissions and notifications on a specified Scheduler, asynchronously with an unbounded buffer with Flowable.bufferSize() "island size".
observeOn(Scheduler, boolean) - Method in class io.reactivex.Observable
Modifies an ObservableSource to perform its emissions and notifications on a specified Scheduler, asynchronously with an unbounded buffer with Flowable.bufferSize() "island size" and optionally delays onError notifications.
observeOn(Scheduler, boolean, int) - Method in class io.reactivex.Observable
Modifies an ObservableSource to perform its emissions and notifications on a specified Scheduler, asynchronously with an unbounded buffer of configurable "island size" and optionally delays onError notifications.
observeOn(Scheduler) - Method in class io.reactivex.Single
Modifies a Single to emit its item (or notify of its error) on a specified Scheduler, asynchronously.
Observer<T> - Interface in io.reactivex
Provides a mechanism for receiving push-based notifications.
observerOnComplete(Observer<T>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
observerOnError(Observer<T>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
observerOnNext(Observer<T>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
ObserverResourceWrapper<T> - Class in io.reactivex.internal.operators.observable
 
ObserverResourceWrapper(Observer<? super T>) - Constructor for class io.reactivex.internal.operators.observable.ObserverResourceWrapper
 
offer(Object) - Method in enum io.reactivex.internal.disposables.EmptyDisposable
 
offer(Object, Object) - Method in enum io.reactivex.internal.disposables.EmptyDisposable
 
offer(T) - Method in interface io.reactivex.internal.fuseable.SimpleQueue
Atomically enqueue a single.
offer(T, T) - Method in interface io.reactivex.internal.fuseable.SimpleQueue
Atomically enqueue two values.
offer(R) - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
offer(R, R) - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
offer(T) - Method in class io.reactivex.internal.observers.BasicIntQueueDisposable
 
offer(T, T) - Method in class io.reactivex.internal.observers.BasicIntQueueDisposable
 
offer(T) - Method in class io.reactivex.internal.observers.BasicQueueDisposable
 
offer(T, T) - Method in class io.reactivex.internal.observers.BasicQueueDisposable
 
offer(T) - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
offer(T, T) - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
offer(T) - Method in class io.reactivex.internal.queue.MpscLinkedQueue
Atomically enqueue a single.
offer(T, T) - Method in class io.reactivex.internal.queue.MpscLinkedQueue
 
offer(E) - Method in class io.reactivex.internal.queue.SpscArrayQueue
 
offer(E, E) - Method in class io.reactivex.internal.queue.SpscArrayQueue
 
offer(T) - Method in class io.reactivex.internal.queue.SpscLinkedArrayQueue
Atomically enqueue a single.
offer(T, T) - Method in class io.reactivex.internal.queue.SpscLinkedArrayQueue
Offer two elements at the same time.
offer(R) - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
offer(R, R) - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
offer(R) - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
offer(R, R) - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
offer(T) - Method in class io.reactivex.internal.subscriptions.BasicIntQueueSubscription
 
offer(T, T) - Method in class io.reactivex.internal.subscriptions.BasicIntQueueSubscription
 
offer(T) - Method in class io.reactivex.internal.subscriptions.BasicQueueSubscription
 
offer(T, T) - Method in class io.reactivex.internal.subscriptions.BasicQueueSubscription
 
offer(Object) - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
offer(Object, Object) - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
offer(T) - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
 
offer(T, T) - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
 
offer(T) - Method in class io.reactivex.processors.BehaviorProcessor
Tries to emit the item to all currently subscribed Subscribers if all of them has requested some value, returns false otherwise.
offer(T) - Method in class io.reactivex.processors.MulticastProcessor
Tries to offer an item into the internal queue and returns false if the queue is full.
offer(T) - Method in class io.reactivex.processors.PublishProcessor
Tries to emit the item to all currently subscribed Subscribers if all of them has requested some value, returns false otherwise.
ofType(Class<U>) - Method in class io.reactivex.Flowable
Filters the items emitted by a Publisher, only emitting those of the specified type.
ofType(Class<U>) - Method in class io.reactivex.Maybe
Filters the items emitted by a Maybe, only emitting its success value if that is an instance of the supplied Class.
ofType(Class<U>) - Method in class io.reactivex.Observable
Filters the items emitted by an ObservableSource, only emitting those of the specified type.
ON_ERROR_MISSING - Static variable in class io.reactivex.internal.functions.Functions
Wraps the consumed Throwable into an OnErrorNotImplementedException and signals it to the plugin error handler.
onAssembly(Maybe<T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onAssembly(Flowable<T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onAssembly(ConnectableFlowable<T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onAssembly(Observable<T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onAssembly(ConnectableObservable<T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onAssembly(Single<T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onAssembly(Completable) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onAssembly(ParallelFlowable<T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onBackpressureBuffer() - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer these items indefinitely until they can be emitted.
onBackpressureBuffer(boolean) - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer these items indefinitely until they can be emitted.
onBackpressureBuffer(int) - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureBuffer(int, boolean) - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureBuffer(int, boolean, boolean) - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureBuffer(int, boolean, boolean, Action) - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureBuffer(int, Action) - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureBuffer(long, Action, BackpressureOverflowStrategy) - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureDrop() - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to discard, rather than emit, those items that its Subscriber is not prepared to observe.
onBackpressureDrop(Consumer<? super T>) - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to discard, rather than emit, those items that its Subscriber is not prepared to observe.
onBackpressureLatest() - Method in class io.reactivex.Flowable
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to hold onto the latest value and emit that on request.
onBeforeBlocking() - Static method in class io.reactivex.plugins.RxJavaPlugins
Called before an operator attempts a blocking operation such as awaiting a condition or signal and should return true to indicate the operator should not block but throw an IllegalArgumentException.
onComplete() - Method in interface io.reactivex.CompletableEmitter
Signal the completion.
onComplete() - Method in interface io.reactivex.CompletableObserver
Called once the deferred computation completes normally.
onComplete() - Method in interface io.reactivex.Emitter
Signal a completion.
onComplete() - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
onComplete() - Method in class io.reactivex.internal.observers.BlockingBaseObserver
 
onComplete() - Method in class io.reactivex.internal.observers.BlockingMultiObserver
 
onComplete() - Method in class io.reactivex.internal.observers.BlockingObserver
 
onComplete() - Method in class io.reactivex.internal.observers.CallbackCompletableObserver
 
onComplete() - Method in class io.reactivex.internal.observers.DeferredScalarObserver
 
onComplete() - Method in class io.reactivex.internal.observers.DisposableLambdaObserver
 
onComplete() - Method in class io.reactivex.internal.observers.EmptyCompletableObserver
 
onComplete() - Method in class io.reactivex.internal.observers.ForEachWhileObserver
 
onComplete() - Method in class io.reactivex.internal.observers.FutureObserver
 
onComplete() - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
onComplete() - Method in class io.reactivex.internal.observers.LambdaObserver
 
onComplete() - Method in class io.reactivex.internal.observers.SubscriberCompletableObserver
 
onComplete() - Method in class io.reactivex.internal.operators.completable.CompletableCache
 
onComplete() - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
onComplete() - Method in class io.reactivex.internal.operators.maybe.MaybeCache
 
onComplete() - Method in class io.reactivex.internal.operators.maybe.MaybeCallbackObserver
 
onComplete() - Method in class io.reactivex.internal.operators.observable.ObservableGroupBy.GroupByObserver
 
onComplete() - Method in class io.reactivex.internal.operators.observable.ObserverResourceWrapper
 
onComplete() - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.BlockingBaseSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.BlockingSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.DeferredScalarSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.ForEachWhileSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.StrictSubscriber
 
onComplete() - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
onComplete() - Method in enum io.reactivex.internal.util.EmptyComponent
 
onComplete(Subscriber<?>, AtomicInteger, AtomicThrowable) - Static method in class io.reactivex.internal.util.HalfSerializer
Emits an onComplete signal or an onError signal with the given error or indicates the concurrently running onNext should do that.
onComplete(Observer<?>, AtomicInteger, AtomicThrowable) - Static method in class io.reactivex.internal.util.HalfSerializer
Emits an onComplete signal or an onError signal with the given error or indicates the concurrently running onNext should do that.
onComplete() - Method in interface io.reactivex.MaybeEmitter
Signal the completion.
onComplete() - Method in interface io.reactivex.MaybeObserver
Called once the deferred computation completes normally.
onComplete() - Method in interface io.reactivex.Observer
Notifies the Observer that the Observable has finished sending push-based notifications.
onComplete() - Method in class io.reactivex.observers.SafeObserver
 
onComplete() - Method in class io.reactivex.observers.SerializedObserver
 
onComplete() - Method in class io.reactivex.observers.TestObserver
 
onComplete() - Method in class io.reactivex.processors.AsyncProcessor
 
onComplete() - Method in class io.reactivex.processors.BehaviorProcessor
 
onComplete() - Method in class io.reactivex.processors.MulticastProcessor
 
onComplete() - Method in class io.reactivex.processors.PublishProcessor
 
onComplete() - Method in class io.reactivex.processors.ReplayProcessor
 
onComplete() - Method in class io.reactivex.processors.UnicastProcessor
 
onComplete() - Method in class io.reactivex.subjects.AsyncSubject
 
onComplete() - Method in class io.reactivex.subjects.BehaviorSubject
 
onComplete() - Method in class io.reactivex.subjects.CompletableSubject
 
onComplete() - Method in class io.reactivex.subjects.MaybeSubject
 
onComplete() - Method in class io.reactivex.subjects.PublishSubject
 
onComplete() - Method in class io.reactivex.subjects.ReplaySubject
 
onComplete() - Method in class io.reactivex.subjects.UnicastSubject
 
onComplete() - Method in class io.reactivex.subscribers.SafeSubscriber
 
onComplete() - Method in class io.reactivex.subscribers.SerializedSubscriber
 
onComplete() - Method in class io.reactivex.subscribers.TestSubscriber
 
onComputationScheduler(Scheduler) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onDrop(R) - Method in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
Called in case of multiple calls to complete.
onError(Throwable) - Method in interface io.reactivex.CompletableEmitter
Signal an exception.
onError(Throwable) - Method in interface io.reactivex.CompletableObserver
Called once if the deferred computation 'throws' an exception.
onError(Throwable) - Method in interface io.reactivex.Emitter
Signal a Throwable exception.
onError(Throwable) - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.BiConsumerSingleObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.BlockingFirstObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.BlockingLastObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.BlockingMultiObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.BlockingObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.CallbackCompletableObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.ConsumerSingleObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.DeferredScalarObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.DisposableLambdaObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.EmptyCompletableObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.ForEachWhileObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.FutureObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.LambdaObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.ResumeSingleObserver
 
onError(Throwable) - Method in class io.reactivex.internal.observers.SubscriberCompletableObserver
 
onError(Throwable) - Method in class io.reactivex.internal.operators.completable.CompletableCache
 
onError(Throwable) - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.operators.maybe.MaybeCache
 
onError(Throwable) - Method in class io.reactivex.internal.operators.maybe.MaybeCallbackObserver
 
onError(Throwable) - Method in class io.reactivex.internal.operators.observable.ObservableGroupBy.GroupByObserver
 
onError(Throwable) - Method in class io.reactivex.internal.operators.observable.ObserverResourceWrapper
 
onError(Throwable) - Method in class io.reactivex.internal.operators.single.SingleCache
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.BlockingFirstSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.BlockingLastSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.BlockingSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.DeferredScalarSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.ForEachWhileSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.StrictSubscriber
 
onError(Throwable) - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
onError(Throwable) - Method in enum io.reactivex.internal.util.EmptyComponent
 
onError(Subscriber<?>, Throwable, AtomicInteger, AtomicThrowable) - Static method in class io.reactivex.internal.util.HalfSerializer
Emits the given exception if possible or adds it to the given error container to be emitted by a concurrent onNext if one is running.
onError(Observer<?>, Throwable, AtomicInteger, AtomicThrowable) - Static method in class io.reactivex.internal.util.HalfSerializer
Emits the given exception if possible or adds it to the given error container to be emitted by a concurrent onNext if one is running.
onError(Throwable) - Method in interface io.reactivex.MaybeEmitter
Signal an exception.
onError(Throwable) - Method in interface io.reactivex.MaybeObserver
Notifies the MaybeObserver that the Maybe has experienced an error condition.
onError(Throwable) - Method in interface io.reactivex.Observer
Notifies the Observer that the Observable has experienced an error condition.
onError(Throwable) - Method in class io.reactivex.observers.SafeObserver
 
onError(Throwable) - Method in class io.reactivex.observers.SerializedObserver
 
onError(Throwable) - Method in class io.reactivex.observers.TestObserver
 
onError(Throwable) - Static method in class io.reactivex.plugins.RxJavaPlugins
Called when an undeliverable error occurs.
onError(Throwable) - Method in class io.reactivex.processors.AsyncProcessor
 
onError(Throwable) - Method in class io.reactivex.processors.BehaviorProcessor
 
onError(Throwable) - Method in class io.reactivex.processors.MulticastProcessor
 
onError(Throwable) - Method in class io.reactivex.processors.PublishProcessor
 
onError(Throwable) - Method in class io.reactivex.processors.ReplayProcessor
 
onError(Throwable) - Method in class io.reactivex.processors.UnicastProcessor
 
onError(Throwable) - Method in interface io.reactivex.SingleEmitter
Signal an exception.
onError(Throwable) - Method in interface io.reactivex.SingleObserver
Notifies the SingleObserver that the Single has experienced an error condition.
onError(Throwable) - Method in class io.reactivex.subjects.AsyncSubject
 
onError(Throwable) - Method in class io.reactivex.subjects.BehaviorSubject
 
onError(Throwable) - Method in class io.reactivex.subjects.CompletableSubject
 
onError(Throwable) - Method in class io.reactivex.subjects.MaybeSubject
 
onError(Throwable) - Method in class io.reactivex.subjects.PublishSubject
 
onError(Throwable) - Method in class io.reactivex.subjects.ReplaySubject
 
onError(Throwable) - Method in class io.reactivex.subjects.SingleSubject
 
onError(Throwable) - Method in class io.reactivex.subjects.UnicastSubject
 
onError(Throwable) - Method in class io.reactivex.subscribers.SafeSubscriber
 
onError(Throwable) - Method in class io.reactivex.subscribers.SerializedSubscriber
 
onError(Throwable) - Method in class io.reactivex.subscribers.TestSubscriber
 
onErrorComplete() - Method in class io.reactivex.Completable
Returns a Completable instance that if this Completable emits an error, it will emit an onComplete and swallow the throwable.
onErrorComplete(Predicate<? super Throwable>) - Method in class io.reactivex.Completable
Returns a Completable instance that if this Completable emits an error and the predicate returns true, it will emit an onComplete and swallow the throwable.
onErrorComplete() - Method in class io.reactivex.Maybe
Returns a Maybe instance that if this Maybe emits an error, it will emit an onComplete and swallow the throwable.
onErrorComplete(Predicate<? super Throwable>) - Method in class io.reactivex.Maybe
Returns a Maybe instance that if this Maybe emits an error and the predicate returns true, it will emit an onComplete and swallow the throwable.
OnErrorNotImplementedException - Exception in io.reactivex.exceptions
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.
OnErrorNotImplementedException(String, Throwable) - Constructor for exception io.reactivex.exceptions.OnErrorNotImplementedException
Customizes the Throwable with a custom message and wraps it before it is signalled to the RxJavaPlugins.onError() handler as OnErrorNotImplementedException.
OnErrorNotImplementedException(Throwable) - Constructor for exception io.reactivex.exceptions.OnErrorNotImplementedException
Wraps the Throwable before it is signalled to the RxJavaPlugins.onError() handler as OnErrorNotImplementedException.
onErrorResumeNext(Function<? super Throwable, ? extends CompletableSource>) - Method in class io.reactivex.Completable
Returns a Completable instance that when encounters an error from this Completable, calls the specified mapper function that returns another Completable instance for it and resumes the execution with it.
onErrorResumeNext(Function<? super Throwable, ? extends Publisher<? extends T>>) - Method in class io.reactivex.Flowable
Instructs a Publisher to pass control to another Publisher rather than invoking onError if it encounters an error.
onErrorResumeNext(Publisher<? extends T>) - Method in class io.reactivex.Flowable
Instructs a Publisher to pass control to another Publisher rather than invoking onError if it encounters an error.
onErrorResumeNext(MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Instructs a Maybe to pass control to another MaybeSource rather than invoking onError if it encounters an error.
onErrorResumeNext(Function<? super Throwable, ? extends MaybeSource<? extends T>>) - Method in class io.reactivex.Maybe
Instructs a Maybe to pass control to another Maybe rather than invoking onError if it encounters an error.
onErrorResumeNext(Function<? super Throwable, ? extends ObservableSource<? extends T>>) - Method in class io.reactivex.Observable
Instructs an ObservableSource to pass control to another ObservableSource rather than invoking onError if it encounters an error.
onErrorResumeNext(ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Instructs an ObservableSource to pass control to another ObservableSource rather than invoking onError if it encounters an error.
onErrorResumeNext(Single<? extends T>) - Method in class io.reactivex.Single
Instructs a Single to pass control to another Single rather than invoking SingleObserver.onError(Throwable) if it encounters an error.
onErrorResumeNext(Function<? super Throwable, ? extends SingleSource<? extends T>>) - Method in class io.reactivex.Single
Instructs a Single to pass control to another Single rather than invoking SingleObserver.onError(Throwable) if it encounters an error.
onErrorReturn(Function<? super Throwable, ? extends T>) - Method in class io.reactivex.Flowable
Instructs a Publisher to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturn(Function<? super Throwable, ? extends T>) - Method in class io.reactivex.Maybe
Instructs a Maybe to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturn(Function<? super Throwable, ? extends T>) - Method in class io.reactivex.Observable
Instructs an ObservableSource to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturn(Function<Throwable, ? extends T>) - Method in class io.reactivex.Single
Instructs a Single to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturnItem(T) - Method in class io.reactivex.Flowable
Instructs a Publisher to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturnItem(T) - Method in class io.reactivex.Maybe
Instructs a Maybe to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturnItem(T) - Method in class io.reactivex.Observable
Instructs an ObservableSource to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturnItem(T) - Method in class io.reactivex.Single
Signals the specified value as success in case the current Single signals an error.
onExceptionResumeNext(Publisher<? extends T>) - Method in class io.reactivex.Flowable
Instructs a Publisher to pass control to another Publisher rather than invoking onError if it encounters an Exception.
onExceptionResumeNext(MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Instructs a Maybe to pass control to another MaybeSource rather than invoking onError if it encounters an Exception.
onExceptionResumeNext(ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Instructs an ObservableSource to pass control to another ObservableSource rather than invoking onError if it encounters an Exception.
onIoScheduler(Scheduler) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onNewThreadScheduler(Scheduler) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onNext(T) - Method in interface io.reactivex.Emitter
Signal a normal value.
onNext(T) - Method in class io.reactivex.internal.observers.BlockingFirstObserver
 
onNext(T) - Method in class io.reactivex.internal.observers.BlockingLastObserver
 
onNext(T) - Method in class io.reactivex.internal.observers.BlockingObserver
 
onNext(T) - Method in class io.reactivex.internal.observers.DisposableLambdaObserver
 
onNext(T) - Method in class io.reactivex.internal.observers.ForEachWhileObserver
 
onNext(T) - Method in class io.reactivex.internal.observers.FutureObserver
 
onNext(T) - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
onNext(T) - Method in class io.reactivex.internal.observers.LambdaObserver
 
onNext(T) - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
onNext(T) - Method in class io.reactivex.internal.operators.observable.ObservableGroupBy.GroupByObserver
 
onNext(T) - Method in class io.reactivex.internal.operators.observable.ObserverResourceWrapper
 
onNext(T) - Method in class io.reactivex.internal.subscribers.BlockingFirstSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.BlockingLastSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.BlockingSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.ForEachWhileSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.StrictSubscriber
 
onNext(T) - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
onNext(Object) - Method in enum io.reactivex.internal.util.EmptyComponent
 
onNext(Subscriber<? super T>, T, AtomicInteger, AtomicThrowable) - Static method in class io.reactivex.internal.util.HalfSerializer
Emits the given value if possible and terminates if there was an onComplete or onError while emitting, drops the value otherwise.
onNext(Observer<? super T>, T, AtomicInteger, AtomicThrowable) - Static method in class io.reactivex.internal.util.HalfSerializer
Emits the given value if possible and terminates if there was an onComplete or onError while emitting, drops the value otherwise.
onNext(T) - Method in interface io.reactivex.Observer
Provides the Observer with a new item to observe.
onNext(T) - Method in class io.reactivex.observers.SafeObserver
 
onNext(T) - Method in class io.reactivex.observers.SerializedObserver
 
onNext(T) - Method in class io.reactivex.observers.TestObserver
 
onNext(T) - Method in class io.reactivex.processors.AsyncProcessor
 
onNext(T) - Method in class io.reactivex.processors.BehaviorProcessor
 
onNext(T) - Method in class io.reactivex.processors.MulticastProcessor
 
onNext(T) - Method in class io.reactivex.processors.PublishProcessor
 
onNext(T) - Method in class io.reactivex.processors.ReplayProcessor
 
onNext(T) - Method in class io.reactivex.processors.UnicastProcessor
 
onNext(T) - Method in class io.reactivex.subjects.AsyncSubject
 
onNext(T) - Method in class io.reactivex.subjects.BehaviorSubject
 
onNext(T) - Method in class io.reactivex.subjects.PublishSubject
 
onNext(T) - Method in class io.reactivex.subjects.ReplaySubject
 
onNext(T) - Method in class io.reactivex.subjects.UnicastSubject
 
onNext(T) - Method in class io.reactivex.subscribers.SafeSubscriber
 
onNext(T) - Method in class io.reactivex.subscribers.SerializedSubscriber
 
onNext(T) - Method in class io.reactivex.subscribers.TestSubscriber
 
onSchedule(Runnable) - Static method in class io.reactivex.plugins.RxJavaPlugins
Called when a task is scheduled.
onSingleScheduler(Scheduler) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onStart() - Method in class io.reactivex.observers.DefaultObserver
Called once the subscription has been set on this observer; override this to perform initialization.
onStart() - Method in class io.reactivex.observers.DisposableCompletableObserver
Called once the single upstream Disposable is set via onSubscribe.
onStart() - Method in class io.reactivex.observers.DisposableMaybeObserver
Called once the single upstream Disposable is set via onSubscribe.
onStart() - Method in class io.reactivex.observers.DisposableObserver
Called once the single upstream Disposable is set via onSubscribe.
onStart() - Method in class io.reactivex.observers.DisposableSingleObserver
Called once the single upstream Disposable is set via onSubscribe.
onStart() - Method in class io.reactivex.observers.ResourceCompletableObserver
Called once the upstream sets a Subscription on this ResourceObserver.
onStart() - Method in class io.reactivex.observers.ResourceMaybeObserver
Called once the upstream sets a Subscription on this ResourceObserver.
onStart() - Method in class io.reactivex.observers.ResourceObserver
Called once the upstream sets a Subscription on this ResourceObserver.
onStart() - Method in class io.reactivex.observers.ResourceSingleObserver
Called once the upstream sets a Subscription on this ResourceObserver.
onStart() - Method in class io.reactivex.subscribers.DefaultSubscriber
Called once the subscription has been set on this observer; override this to perform initialization or issue an initial request.
onStart() - Method in class io.reactivex.subscribers.DisposableSubscriber
Called once the single upstream Subscription is set via onSubscribe.
onStart() - Method in class io.reactivex.subscribers.ResourceSubscriber
Called once the upstream sets a Subscription on this AsyncObserver.
onStart() - Method in class io.reactivex.subscribers.TestSubscriber
Called after the onSubscribe is called and handled.
onSubscribe(Disposable) - Method in interface io.reactivex.CompletableObserver
Called once by the Completable to set a Disposable on this instance which then can be used to cancel the subscription at any time.
onSubscribe(Subscription) - Method in interface io.reactivex.FlowableSubscriber
Implementors of this method should make sure everything that needs to be visible in Subscriber.onNext(Object) is established before calling Subscription.request(long).
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.BasicFuseableObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.BiConsumerSingleObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.BlockingBaseObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.BlockingMultiObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.BlockingObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.CallbackCompletableObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.ConsumerSingleObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.DeferredScalarObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.DisposableLambdaObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.EmptyCompletableObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.ForEachWhileObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.FutureObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.LambdaObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.ResumeSingleObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.observers.SubscriberCompletableObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.operators.completable.CompletableCache
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.operators.maybe.MaybeCache
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.operators.maybe.MaybeCallbackObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.operators.observable.ObservableGroupBy.GroupByObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.operators.observable.ObserverResourceWrapper
 
onSubscribe(Disposable) - Method in class io.reactivex.internal.operators.single.SingleCache
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.BlockingBaseSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.BlockingSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.DeferredScalarSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.ForEachWhileSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.StrictSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
onSubscribe(Disposable) - Method in enum io.reactivex.internal.util.EmptyComponent
 
onSubscribe(Subscription) - Method in enum io.reactivex.internal.util.EmptyComponent
 
onSubscribe(Disposable) - Method in interface io.reactivex.MaybeObserver
Provides the MaybeObserver with the means of cancelling (disposing) the connection (channel) with the Maybe in both synchronous (from within onSubscribe(Disposable) itself) and asynchronous manner.
onSubscribe(Disposable) - Method in interface io.reactivex.Observer
Provides the Observer with the means of cancelling (disposing) the connection (channel) with the Observable in both synchronous (from within Observer.onNext(Object)) and asynchronous manner.
onSubscribe(Disposable) - Method in class io.reactivex.observers.DefaultObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.DisposableCompletableObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.DisposableMaybeObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.DisposableObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.DisposableSingleObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.ResourceCompletableObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.ResourceMaybeObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.ResourceObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.ResourceSingleObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.SafeObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.SerializedObserver
 
onSubscribe(Disposable) - Method in class io.reactivex.observers.TestObserver
 
onSubscribe(Flowable<T>, Subscriber<? super T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onSubscribe(Observable<T>, Observer<? super T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onSubscribe(Single<T>, SingleObserver<? super T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onSubscribe(Completable, CompletableObserver) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onSubscribe(Maybe<T>, MaybeObserver<? super T>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Calls the associated hook function.
onSubscribe(Subscription) - Method in class io.reactivex.processors.AsyncProcessor
 
onSubscribe(Subscription) - Method in class io.reactivex.processors.BehaviorProcessor
 
onSubscribe(Subscription) - Method in class io.reactivex.processors.MulticastProcessor
 
onSubscribe(Subscription) - Method in class io.reactivex.processors.PublishProcessor
 
onSubscribe(Subscription) - Method in class io.reactivex.processors.ReplayProcessor
 
onSubscribe(Subscription) - Method in class io.reactivex.processors.UnicastProcessor
 
onSubscribe(Disposable) - Method in interface io.reactivex.SingleObserver
Provides the SingleObserver with the means of cancelling (disposing) the connection (channel) with the Single in both synchronous (from within onSubscribe(Disposable) itself) and asynchronous manner.
onSubscribe(Disposable) - Method in class io.reactivex.subjects.AsyncSubject
 
onSubscribe(Disposable) - Method in class io.reactivex.subjects.BehaviorSubject
 
onSubscribe(Disposable) - Method in class io.reactivex.subjects.CompletableSubject
 
onSubscribe(Disposable) - Method in class io.reactivex.subjects.MaybeSubject
 
onSubscribe(Disposable) - Method in class io.reactivex.subjects.PublishSubject
 
onSubscribe(Disposable) - Method in class io.reactivex.subjects.ReplaySubject
 
onSubscribe(Disposable) - Method in class io.reactivex.subjects.SingleSubject
 
onSubscribe(Disposable) - Method in class io.reactivex.subjects.UnicastSubject
 
onSubscribe(Subscription) - Method in class io.reactivex.subscribers.DefaultSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.subscribers.DisposableSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.subscribers.ResourceSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.subscribers.SafeSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.subscribers.SerializedSubscriber
 
onSubscribe(Subscription) - Method in class io.reactivex.subscribers.TestSubscriber
 
onSuccess(T) - Method in class io.reactivex.internal.observers.BiConsumerSingleObserver
 
onSuccess(T) - Method in class io.reactivex.internal.observers.BlockingMultiObserver
 
onSuccess(T) - Method in class io.reactivex.internal.observers.ConsumerSingleObserver
 
onSuccess(T) - Method in class io.reactivex.internal.observers.FutureSingleObserver
 
onSuccess(T) - Method in class io.reactivex.internal.observers.ResumeSingleObserver
 
onSuccess(T) - Method in class io.reactivex.internal.operators.maybe.MaybeCache
 
onSuccess(T) - Method in class io.reactivex.internal.operators.maybe.MaybeCallbackObserver
 
onSuccess(T) - Method in class io.reactivex.internal.operators.single.SingleCache
 
onSuccess(Object) - Method in enum io.reactivex.internal.util.EmptyComponent
 
onSuccess(T) - Method in interface io.reactivex.MaybeEmitter
Signal a success value.
onSuccess(T) - Method in interface io.reactivex.MaybeObserver
Notifies the MaybeObserver with one item and that the Maybe has finished sending push-based notifications.
onSuccess(T) - Method in class io.reactivex.observers.TestObserver
 
onSuccess(T) - Method in interface io.reactivex.SingleEmitter
Signal a success value.
onSuccess(T) - Method in interface io.reactivex.SingleObserver
Notifies the SingleObserver with a single item and that the Single has finished sending push-based notifications.
onSuccess(T) - Method in class io.reactivex.subjects.MaybeSubject
 
onSuccess(T) - Method in class io.reactivex.subjects.SingleSubject
 
onTerminateDetach() - Method in class io.reactivex.Completable
Nulls out references to the upstream producer and downstream CompletableObserver if the sequence is terminated or downstream calls dispose().
onTerminateDetach() - Method in class io.reactivex.Flowable
Nulls out references to the upstream producer and downstream Subscriber if the sequence is terminated or downstream cancels.
onTerminateDetach() - Method in class io.reactivex.Maybe
Nulls out references to the upstream producer and downstream MaybeObserver if the sequence is terminated or downstream calls dispose().
onTerminateDetach() - Method in class io.reactivex.Observable
Nulls out references to the upstream producer and downstream Observer if the sequence is terminated or downstream calls dispose().
onTerminateDetach() - Method in class io.reactivex.Single
Nulls out references to the upstream producer and downstream SingleObserver if the sequence is terminated or downstream calls dispose().
onWorker(int, Scheduler.Worker) - Method in interface io.reactivex.internal.schedulers.SchedulerMultiWorkerSupport.WorkerCallback
Called with the Worker index and instance.
OpenHashSet<T> - Class in io.reactivex.internal.util
A simple open hash set with add, remove and clear capabilities only.
OpenHashSet() - Constructor for class io.reactivex.internal.util.OpenHashSet
 
OpenHashSet(int) - Constructor for class io.reactivex.internal.util.OpenHashSet
Creates an OpenHashSet with the initial capacity and load factor of 0.75f.
OpenHashSet(int, float) - Constructor for class io.reactivex.internal.util.OpenHashSet
 

P

parallel() - Method in class io.reactivex.Flowable
Parallelizes the flow by creating multiple 'rails' (equal to the number of CPUs) and dispatches the upstream items to them in a round-robin fashion.
parallel(int) - Method in class io.reactivex.Flowable
Parallelizes the flow by creating the specified number of 'rails' and dispatches the upstream items to them in a round-robin fashion.
parallel(int, int) - Method in class io.reactivex.Flowable
Parallelizes the flow by creating the specified number of 'rails' and dispatches the upstream items to them in a round-robin fashion and uses the defined per-'rail' prefetch amount.
ParallelCollect<T,C> - Class in io.reactivex.internal.operators.parallel
Reduce the sequence of values in each 'rail' to a single value.
ParallelCollect(ParallelFlowable<? extends T>, Callable<? extends C>, BiConsumer<? super C, ? super T>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelCollect
 
ParallelConcatMap<T,R> - Class in io.reactivex.internal.operators.parallel
Concatenates the generated Publishers on each rail.
ParallelConcatMap(ParallelFlowable<T>, Function<? super T, ? extends Publisher<? extends R>>, int, ErrorMode) - Constructor for class io.reactivex.internal.operators.parallel.ParallelConcatMap
 
ParallelDoOnNextTry<T> - Class in io.reactivex.internal.operators.parallel
Calls a Consumer for each upstream value passing by and handles any failure with a handler function.
ParallelDoOnNextTry(ParallelFlowable<T>, Consumer<? super T>, BiFunction<? super Long, ? super Throwable, ParallelFailureHandling>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelDoOnNextTry
 
ParallelFailureHandling - Enum in io.reactivex.parallel
Enumerations for handling failure within a parallel operator.
ParallelFilter<T> - Class in io.reactivex.internal.operators.parallel
Filters each 'rail' of the source ParallelFlowable with a predicate function.
ParallelFilter(ParallelFlowable<T>, Predicate<? super T>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelFilter
 
ParallelFilterTry<T> - Class in io.reactivex.internal.operators.parallel
Filters each 'rail' of the source ParallelFlowable with a predicate function.
ParallelFilterTry(ParallelFlowable<T>, Predicate<? super T>, BiFunction<? super Long, ? super Throwable, ParallelFailureHandling>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelFilterTry
 
ParallelFlatMap<T,R> - Class in io.reactivex.internal.operators.parallel
Flattens the generated Publishers on each rail.
ParallelFlatMap(ParallelFlowable<T>, Function<? super T, ? extends Publisher<? extends R>>, boolean, int, int) - Constructor for class io.reactivex.internal.operators.parallel.ParallelFlatMap
 
ParallelFlowable<T> - Class in io.reactivex.parallel
Abstract base class for Parallel publishers that take an array of Subscribers.
ParallelFlowable() - Constructor for class io.reactivex.parallel.ParallelFlowable
 
ParallelFlowableConverter<T,R> - Interface in io.reactivex.parallel
Convenience interface and callback used by the ParallelFlowable.as(io.reactivex.parallel.ParallelFlowableConverter<T, R>) operator to turn a ParallelFlowable into another value fluently.
ParallelFromArray<T> - Class in io.reactivex.internal.operators.parallel
Wraps multiple Publishers into a ParallelFlowable which runs them in parallel.
ParallelFromArray(Publisher<T>[]) - Constructor for class io.reactivex.internal.operators.parallel.ParallelFromArray
 
ParallelFromPublisher<T> - Class in io.reactivex.internal.operators.parallel
Dispatches the values from upstream in a round robin fashion to subscribers which are ready to consume elements.
ParallelFromPublisher(Publisher<? extends T>, int, int) - Constructor for class io.reactivex.internal.operators.parallel.ParallelFromPublisher
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelCollect
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelConcatMap
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelDoOnNextTry
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelFilter
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelFilterTry
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelFlatMap
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelFromArray
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelFromPublisher
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelMap
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelMapTry
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelPeek
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelReduce
 
parallelism() - Method in class io.reactivex.internal.operators.parallel.ParallelRunOn
 
parallelism() - Method in class io.reactivex.parallel.ParallelFlowable
Returns the number of expected parallel Subscribers.
ParallelJoin<T> - Class in io.reactivex.internal.operators.parallel
Merges the individual 'rails' of the source ParallelFlowable, unordered, into a single regular Publisher sequence (exposed as Flowable).
ParallelJoin(ParallelFlowable<? extends T>, int, boolean) - Constructor for class io.reactivex.internal.operators.parallel.ParallelJoin
 
ParallelMap<T,R> - Class in io.reactivex.internal.operators.parallel
Maps each 'rail' of the source ParallelFlowable with a mapper function.
ParallelMap(ParallelFlowable<T>, Function<? super T, ? extends R>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelMap
 
ParallelMapTry<T,R> - Class in io.reactivex.internal.operators.parallel
Maps each 'rail' of the source ParallelFlowable with a mapper function and handle any failure based on a handler function.
ParallelMapTry(ParallelFlowable<T>, Function<? super T, ? extends R>, BiFunction<? super Long, ? super Throwable, ParallelFailureHandling>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelMapTry
 
ParallelPeek<T> - Class in io.reactivex.internal.operators.parallel
Execute a Consumer in each 'rail' for the current element passing through.
ParallelPeek(ParallelFlowable<T>, Consumer<? super T>, Consumer<? super T>, Consumer<? super Throwable>, Action, Action, Consumer<? super Subscription>, LongConsumer, Action) - Constructor for class io.reactivex.internal.operators.parallel.ParallelPeek
 
ParallelReduce<T,R> - Class in io.reactivex.internal.operators.parallel
Reduce the sequence of values in each 'rail' to a single value.
ParallelReduce(ParallelFlowable<? extends T>, Callable<R>, BiFunction<R, ? super T, R>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelReduce
 
ParallelReduceFull<T> - Class in io.reactivex.internal.operators.parallel
Reduces all 'rails' into a single value which then gets reduced into a single Publisher sequence.
ParallelReduceFull(ParallelFlowable<? extends T>, BiFunction<T, T, T>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelReduceFull
 
ParallelRunOn<T> - Class in io.reactivex.internal.operators.parallel
Ensures each 'rail' from upstream runs on a Worker from a Scheduler.
ParallelRunOn(ParallelFlowable<? extends T>, Scheduler, int) - Constructor for class io.reactivex.internal.operators.parallel.ParallelRunOn
 
ParallelSortedJoin<T> - Class in io.reactivex.internal.operators.parallel
Given sorted rail sequences (according to the provided comparator) as List emit the smallest item from these parallel Lists to the Subscriber.
ParallelSortedJoin(ParallelFlowable<List<T>>, Comparator<? super T>) - Constructor for class io.reactivex.internal.operators.parallel.ParallelSortedJoin
 
ParallelTransformer<Upstream,Downstream> - Interface in io.reactivex.parallel
Interface to compose ParallelFlowable.
peek() - Method in class io.reactivex.internal.queue.SpscLinkedArrayQueue
 
poll() - Method in enum io.reactivex.internal.disposables.EmptyDisposable
 
poll() - Method in interface io.reactivex.internal.fuseable.SimplePlainQueue
 
poll() - Method in interface io.reactivex.internal.fuseable.SimpleQueue
Tries to dequeue a value (non-null) or returns null if the queue is empty.
poll() - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
 
poll() - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
poll() - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
poll() - Method in class io.reactivex.internal.queue.MpscLinkedQueue
Tries to dequeue a value (non-null) or returns null if the queue is empty.
poll() - Method in class io.reactivex.internal.queue.SpscArrayQueue
 
poll() - Method in class io.reactivex.internal.queue.SpscLinkedArrayQueue
Tries to dequeue a value (non-null) or returns null if the queue is empty.
poll() - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
 
poll() - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
poll() - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
 
postComplete(Subscriber<? super T>, Queue<T>, AtomicLong, BooleanSupplier) - Static method in class io.reactivex.internal.util.QueueDrainHelper
Signals the completion of the main sequence and switches to post-completion replay mode.
postCompleteRequest(long, Subscriber<? super T>, Queue<T>, AtomicLong, BooleanSupplier) - Static method in class io.reactivex.internal.util.QueueDrainHelper
Accumulates requests (not validated) and handles the completed mode draining of the queue based on the requests.
Pow2 - Class in io.reactivex.internal.util
 
Predicate<T> - Interface in io.reactivex.functions
A functional interface (callback) that returns true or false for the given input value.
predicateReverseFor(BooleanSupplier) - Static method in class io.reactivex.internal.functions.Functions
 
printStackTrace() - Method in exception io.reactivex.exceptions.CompositeException
All of the following printStackTrace functionality is derived from JDK Throwable printStackTrace.
printStackTrace(PrintStream) - Method in exception io.reactivex.exceptions.CompositeException
 
printStackTrace(PrintWriter) - Method in exception io.reactivex.exceptions.CompositeException
 
produced(long) - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
produced - Variable in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
Number of values emitted so far.
produced(long) - Method in class io.reactivex.internal.subscriptions.SubscriptionArbiter
 
produced(AtomicLong, long) - Static method in class io.reactivex.internal.util.BackpressureHelper
Atomically subtract the given number (positive, not validated) from the target field unless it contains Long.MAX_VALUE.
produced(long) - Method in interface io.reactivex.internal.util.QueueDrain
 
producedCancel(AtomicLong, long) - Static method in class io.reactivex.internal.util.BackpressureHelper
Atomically subtract the given number (positive, not validated) from the target field if it doesn't contain Long.MIN_VALUE (indicating some cancelled state) or Long.MAX_VALUE (unbounded mode).
propagate(Throwable) - Static method in class io.reactivex.exceptions.Exceptions
Convenience method to throw a RuntimeException and Error directly or wrap any other exception type into a RuntimeException.
ProtocolViolationException - Exception in io.reactivex.exceptions
Explicitly named exception to indicate a Reactive-Streams protocol violation.
ProtocolViolationException(String) - Constructor for exception io.reactivex.exceptions.ProtocolViolationException
Creates an instance with the given message.
publish() - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable, which is a variety of Publisher that waits until its connect method is called before it begins emitting items to those Subscribers that have subscribed to it.
publish(Function<? super Flowable<T>, ? extends Publisher<R>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the underlying sequence.
publish(Function<? super Flowable<T>, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the underlying sequence.
publish(int) - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable, which is a variety of Publisher that waits until its connect method is called before it begins emitting items to those Subscribers that have subscribed to it.
publish() - Method in class io.reactivex.Observable
Returns a ConnectableObservable, which is a variety of ObservableSource that waits until its connect method is called before it begins emitting items to those Observers that have subscribed to it.
publish(Function<? super Observable<T>, ? extends ObservableSource<R>>) - Method in class io.reactivex.Observable
Returns an Observable that emits the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the underlying sequence.
PublishProcessor<T> - Class in io.reactivex.processors
Processor that multicasts all subsequently observed items to its current Subscribers.
PublishSubject<T> - Class in io.reactivex.subjects
A Subject that emits (multicasts) items to currently subscribed Observers and terminal events to current or late Observers.
PURGE_ENABLED - Static variable in class io.reactivex.internal.schedulers.SchedulerPoolFactory
Indicates the periodic purging of the ScheduledExecutorService is enabled.
PURGE_PERIOD_SECONDS - Static variable in class io.reactivex.internal.schedulers.SchedulerPoolFactory
Indicates the purge period of the ScheduledExecutorServices created by create().

Q

qs - Variable in class io.reactivex.internal.observers.BasicFuseableObserver
The upstream's QueueDisposable if not null.
qs - Variable in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
The upstream's QueueSubscription if not null.
qs - Variable in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
The upstream's QueueSubscription if not null.
queue() - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
queue - Variable in class io.reactivex.internal.observers.QueueDrainObserver
 
queue() - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
queue - Variable in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
QueueDisposable<T> - Interface in io.reactivex.internal.fuseable
An interface extending Queue and Disposable and allows negotiating the fusion mode between subsequent operators of the Observable base reactive type.
QueueDrain<T,U> - Interface in io.reactivex.internal.util
 
QueueDrainHelper - Class in io.reactivex.internal.util
Utility class to help with the queue-drain serialization idiom.
QueueDrainObserver<T,U,V> - Class in io.reactivex.internal.observers
Abstract base class for subscribers that hold another subscriber, a queue and requires queue-drain behavior.
QueueDrainObserver(Observer<? super V>, SimplePlainQueue<U>) - Constructor for class io.reactivex.internal.observers.QueueDrainObserver
 
QueueDrainSubscriber<T,U,V> - Class in io.reactivex.internal.subscribers
Abstract base class for subscribers that hold another subscriber, a queue and requires queue-drain behavior.
QueueDrainSubscriber(Subscriber<? super V>, SimplePlainQueue<U>) - Constructor for class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
QueueFuseable<T> - Interface in io.reactivex.internal.fuseable
Represents a SimpleQueue plus the means and constants for requesting a fusion mode.
QueueSubscription<T> - Interface in io.reactivex.internal.fuseable
An interface extending Queue and Subscription and allows negotiating the fusion mode between subsequent operators of the Flowable base reactive type.

R

range(int, int) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits a sequence of Integers within a specified range.
range(int, int) - Static method in class io.reactivex.Observable
Returns an Observable that emits a sequence of Integers within a specified range.
rangeLong(long, long) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits a sequence of Longs within a specified range.
rangeLong(long, long) - Static method in class io.reactivex.Observable
Returns an Observable that emits a sequence of Longs within a specified range.
rebatchRequests(int) - Method in class io.reactivex.Flowable
Requests n initially from the upstream and then 75% of n subsequently after 75% of n values have been emitted to the downstream.
reduce(BiFunction<T, T, T>) - Method in class io.reactivex.Flowable
Returns a Maybe that applies a specified accumulator function to the first item emitted by a source Publisher, then feeds the result of that function along with the second item emitted by the source Publisher into the same function, and so on until all items have been emitted by the finite source Publisher, and emits the final result from the final call to your function as its sole item.
reduce(R, BiFunction<R, ? super T, R>) - Method in class io.reactivex.Flowable
Returns a Single that applies a specified accumulator function to the first item emitted by a source Publisher and a specified seed value, then feeds the result of that function along with the second item emitted by a Publisher into the same function, and so on until all items have been emitted by the finite source Publisher, emitting the final result from the final call to your function as its sole item.
reduce(BiFunction<T, T, T>) - Method in class io.reactivex.Observable
Returns a Maybe that applies a specified accumulator function to the first item emitted by a source ObservableSource, then feeds the result of that function along with the second item emitted by the source ObservableSource into the same function, and so on until all items have been emitted by the finite source ObservableSource, and emits the final result from the final call to your function as its sole item.
reduce(R, BiFunction<R, ? super T, R>) - Method in class io.reactivex.Observable
Returns a Single that applies a specified accumulator function to the first item emitted by a source ObservableSource and a specified seed value, then feeds the result of that function along with the second item emitted by an ObservableSource into the same function, and so on until all items have been emitted by the finite source ObservableSource, emitting the final result from the final call to your function as its sole item.
reduce(BiFunction<T, T, T>) - Method in class io.reactivex.parallel.ParallelFlowable
Reduces all values within a 'rail' and across 'rails' with a reducer function into a single sequential value.
reduce(Callable<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.parallel.ParallelFlowable
Reduces all values within a 'rail' to a single value (with a possibly different type) via a reducer function that is initialized on each rail from an initialSupplier value.
reduceWith(Callable<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.Flowable
Returns a Single that applies a specified accumulator function to the first item emitted by a source Publisher and a seed value derived from calling a specified seedSupplier, then feeds the result of that function along with the second item emitted by a Publisher into the same function, and so on until all items have been emitted by the finite source Publisher, emitting the final result from the final call to your function as its sole item.
reduceWith(Callable<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.Observable
Returns a Single that applies a specified accumulator function to the first item emitted by a source ObservableSource and a seed value derived from calling a specified seedSupplier, then feeds the result of that function along with the second item emitted by an ObservableSource into the same function, and so on until all items have been emitted by the finite source ObservableSource, emitting the final result from the final call to your function as its sole item.
refCount() - Method in class io.reactivex.flowables.ConnectableFlowable
Returns a Flowable that stays connected to this ConnectableFlowable as long as there is at least one subscription to this ConnectableFlowable.
refCount(int) - Method in class io.reactivex.flowables.ConnectableFlowable
Connects to the upstream ConnectableFlowable if the number of subscribed subscriber reaches the specified count and disconnect if all subscribers have unsubscribed.
refCount(long, TimeUnit) - Method in class io.reactivex.flowables.ConnectableFlowable
Connects to the upstream ConnectableFlowable if the number of subscribed subscriber reaches 1 and disconnect after the specified timeout if all subscribers have unsubscribed.
refCount(long, TimeUnit, Scheduler) - Method in class io.reactivex.flowables.ConnectableFlowable
Connects to the upstream ConnectableFlowable if the number of subscribed subscriber reaches 1 and disconnect after the specified timeout if all subscribers have unsubscribed.
refCount(int, long, TimeUnit) - Method in class io.reactivex.flowables.ConnectableFlowable
Connects to the upstream ConnectableFlowable if the number of subscribed subscriber reaches the specified count and disconnect after the specified timeout if all subscribers have unsubscribed.
refCount(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.flowables.ConnectableFlowable
Connects to the upstream ConnectableFlowable if the number of subscribed subscriber reaches the specified count and disconnect after the specified timeout if all subscribers have unsubscribed.
refCount() - Method in class io.reactivex.observables.ConnectableObservable
Returns an Observable that stays connected to this ConnectableObservable as long as there is at least one subscription to this ConnectableObservable.
refCount(int) - Method in class io.reactivex.observables.ConnectableObservable
Connects to the upstream ConnectableObservable if the number of subscribed subscriber reaches the specified count and disconnect if all subscribers have unsubscribed.
refCount(long, TimeUnit) - Method in class io.reactivex.observables.ConnectableObservable
Connects to the upstream ConnectableObservable if the number of subscribed subscriber reaches 1 and disconnect after the specified timeout if all subscribers have unsubscribed.
refCount(long, TimeUnit, Scheduler) - Method in class io.reactivex.observables.ConnectableObservable
Connects to the upstream ConnectableObservable if the number of subscribed subscriber reaches 1 and disconnect after the specified timeout if all subscribers have unsubscribed.
refCount(int, long, TimeUnit) - Method in class io.reactivex.observables.ConnectableObservable
Connects to the upstream ConnectableObservable if the number of subscribed subscriber reaches the specified count and disconnect after the specified timeout if all subscribers have unsubscribed.
refCount(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.observables.ConnectableObservable
Connects to the upstream ConnectableObservable if the number of subscribed subscriber reaches the specified count and disconnect after the specified timeout if all subscribers have unsubscribed.
remove(Disposable) - Method in class io.reactivex.disposables.CompositeDisposable
Removes and disposes the given disposable if it is part of this container.
remove(Disposable) - Method in interface io.reactivex.internal.disposables.DisposableContainer
Removes and disposes the given disposable if it is part of this container.
remove(Disposable) - Method in class io.reactivex.internal.disposables.ListCompositeDisposable
 
remove(T) - Method in class io.reactivex.internal.util.OpenHashSet
 
remove(Object) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
remove(int) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
removeAll(Collection<?>) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
repeat() - Method in class io.reactivex.Completable
Returns a Completable that repeatedly subscribes to this Completable until cancelled.
repeat(long) - Method in class io.reactivex.Completable
Returns a Completable that subscribes repeatedly at most the given times to this Completable.
repeat() - Method in class io.reactivex.Flowable
Returns a Flowable that repeats the sequence of items emitted by the source Publisher indefinitely.
repeat(long) - Method in class io.reactivex.Flowable
Returns a Flowable that repeats the sequence of items emitted by the source Publisher at most count times.
repeat() - Method in class io.reactivex.Maybe
Returns a Flowable that repeats the sequence of items emitted by the source Maybe indefinitely.
repeat(long) - Method in class io.reactivex.Maybe
Returns a Flowable that repeats the sequence of items emitted by the source Maybe at most count times.
repeat() - Method in class io.reactivex.Observable
Returns an Observable that repeats the sequence of items emitted by the source ObservableSource indefinitely.
repeat(long) - Method in class io.reactivex.Observable
Returns an Observable that repeats the sequence of items emitted by the source ObservableSource at most count times.
repeat() - Method in class io.reactivex.Single
Repeatedly re-subscribes to the current Single and emits each success value.
repeat(long) - Method in class io.reactivex.Single
Re-subscribes to the current Single at most the given number of times and emits each success value.
repeatUntil(BooleanSupplier) - Method in class io.reactivex.Completable
Returns a Completable that repeatedly subscribes to this Completable so long as the given stop supplier returns false.
repeatUntil(BooleanSupplier) - Method in class io.reactivex.Flowable
Returns a Flowable that repeats the sequence of items emitted by the source Publisher until the provided stop function returns true.
repeatUntil(BooleanSupplier) - Method in class io.reactivex.Maybe
Returns a Flowable that repeats the sequence of items emitted by the source Maybe until the provided stop function returns true.
repeatUntil(BooleanSupplier) - Method in class io.reactivex.Observable
Returns an Observable that repeats the sequence of items emitted by the source ObservableSource until the provided stop function returns true.
repeatUntil(BooleanSupplier) - Method in class io.reactivex.Single
Re-subscribes to the current Single until the given BooleanSupplier returns true.
repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class io.reactivex.Completable
Returns a Completable instance that repeats when the Publisher returned by the handler emits an item or completes when this Publisher emits a completed event.
repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the same values as the source Publisher with the exception of an onComplete.
repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class io.reactivex.Maybe
Returns a Flowable that emits the same values as the source Publisher with the exception of an onComplete.
repeatWhen(Function<? super Observable<Object>, ? extends ObservableSource<?>>) - Method in class io.reactivex.Observable
Returns an Observable that emits the same values as the source ObservableSource with the exception of an onComplete.
repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class io.reactivex.Single
Re-subscribes to the current Single if the Publisher returned by the handler function signals a value in response to a value signalled through the Flowable the handle receives.
replace(Disposable) - Method in class io.reactivex.disposables.SerialDisposable
Atomically: set the next disposable on this container but don't dispose the previous one (if any) or dispose next if the container has been disposed.
replace(AtomicReference<Disposable>, Disposable) - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Atomically replaces the Disposable in the field with the given new Disposable but does not dispose the old one.
replace(Disposable) - Method in class io.reactivex.internal.disposables.SequentialDisposable
Atomically: set the next disposable on this container but don't dispose the previous one (if any) or dispose next if the container has been disposed.
replace(AtomicReference<Subscription>, Subscription) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Atomically sets the subscription on the field but does not cancel the previous subscription.
replaceResource(int, Disposable) - Method in class io.reactivex.internal.disposables.ArrayCompositeDisposable
Replaces the resource at the specified index and returns the old resource.
replaceResource(int, Subscription) - Method in class io.reactivex.internal.subscriptions.ArrayCompositeSubscription
Replaces the resource at the specified index and returns the old resource.
replaceResource(Disposable) - Method in class io.reactivex.internal.subscriptions.AsyncSubscription
Replaces the currently held resource with the given new one without disposing the old.
replay() - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable that shares a single subscription to the underlying Publisher that will replay all of its items and notifications to any future Subscriber.
replay(Function<? super Flowable<T>, ? extends Publisher<R>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the results of invoking a specified selector on the items emitted by a ConnectableFlowable that shares a single subscription to the source Publisher.
replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the source Publisher, replaying bufferSize notifications.
replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int, long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the source Publisher, replaying no more than bufferSize items that were emitted within a specified time window.
replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int, long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the source Publisher, replaying no more than bufferSize items that were emitted within a specified time window.
replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the source Publisher, replaying a maximum of bufferSize items.
replay(Function<? super Flowable<T>, ? extends Publisher<R>>, long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the source Publisher, replaying all items that were emitted within a specified time window.
replay(Function<? super Flowable<T>, ? extends Publisher<R>>, long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the source Publisher, replaying all items that were emitted within a specified time window.
replay(Function<? super Flowable<T>, ? extends Publisher<R>>, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableFlowable that shares a single subscription to the source Publisher.
replay(int) - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable that shares a single subscription to the source Publisher that replays at most bufferSize items emitted by that Publisher.
replay(int, long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable that shares a single subscription to the source Publisher and replays at most bufferSize items that were emitted during a specified time window.
replay(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable that shares a single subscription to the source Publisher and that replays a maximum of bufferSize items that are emitted within a specified time window.
replay(int, Scheduler) - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable that shares a single subscription to the source Publisher and replays at most bufferSize items emitted by that Publisher.
replay(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable that shares a single subscription to the source Publisher and replays all items emitted by that Publisher within a specified time window.
replay(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable that shares a single subscription to the source Publisher and replays all items emitted by that Publisher within a specified time window.
replay(Scheduler) - Method in class io.reactivex.Flowable
Returns a ConnectableFlowable that shares a single subscription to the source Publisher that will replay all of its items and notifications to any future Subscriber on the given Scheduler.
replay() - Method in class io.reactivex.Observable
Returns a ConnectableObservable that shares a single subscription to the underlying ObservableSource that will replay all of its items and notifications to any future Observer.
replay(Function<? super Observable<T>, ? extends ObservableSource<R>>) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on the items emitted by a ConnectableObservable that shares a single subscription to the source ObservableSource.
replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source ObservableSource, replaying bufferSize notifications.
replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int, long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source ObservableSource, replaying no more than bufferSize items that were emitted within a specified time window.
replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int, long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source ObservableSource, replaying no more than bufferSize items that were emitted within a specified time window.
replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source ObservableSource, replaying a maximum of bufferSize items.
replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source ObservableSource, replaying all items that were emitted within a specified time window.
replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source ObservableSource, replaying all items that were emitted within a specified time window.
replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source ObservableSource.
replay(int) - Method in class io.reactivex.Observable
Returns a ConnectableObservable that shares a single subscription to the source ObservableSource that replays at most bufferSize items emitted by that ObservableSource.
replay(int, long, TimeUnit) - Method in class io.reactivex.Observable
Returns a ConnectableObservable that shares a single subscription to the source ObservableSource and replays at most bufferSize items that were emitted during a specified time window.
replay(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns a ConnectableObservable that shares a single subscription to the source ObservableSource and that replays a maximum of bufferSize items that are emitted within a specified time window.
replay(int, Scheduler) - Method in class io.reactivex.Observable
Returns a ConnectableObservable that shares a single subscription to the source ObservableSource and replays at most bufferSize items emitted by that ObservableSource.
replay(long, TimeUnit) - Method in class io.reactivex.Observable
Returns a ConnectableObservable that shares a single subscription to the source ObservableSource and replays all items emitted by that ObservableSource within a specified time window.
replay(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns a ConnectableObservable that shares a single subscription to the source ObservableSource and replays all items emitted by that ObservableSource within a specified time window.
replay(Scheduler) - Method in class io.reactivex.Observable
Returns a ConnectableObservable that shares a single subscription to the source ObservableSource that will replay all of its items and notifications to any future Observer on the given Scheduler.
replayCallable(Flowable<T>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
replayCallable(Flowable<T>, int) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
replayCallable(Flowable<T>, int, long, TimeUnit, Scheduler) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
replayCallable(Flowable<T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
replayCallable(Observable<T>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
replayCallable(Observable<T>, int) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
replayCallable(Observable<T>, int, long, TimeUnit, Scheduler) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
replayCallable(Observable<T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
replayFunction(Function<? super Flowable<T>, ? extends Publisher<R>>, Scheduler) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
replayFunction(Function<? super Observable<T>, ? extends ObservableSource<R>>, Scheduler) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
ReplayProcessor<T> - Class in io.reactivex.processors
Replays events to Subscribers.
ReplaySubject<T> - Class in io.reactivex.subjects
Replays events (in a configurable bounded or unbounded manner) to current and late Observers.
reportDisposableSet() - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Reports that the disposable is already set to the RxJavaPlugins error handler.
reportDoubleSubscription(Class<?>) - Static method in class io.reactivex.internal.util.EndConsumerHelper
Report a ProtocolViolationException with a personalized message referencing the simple type name of the consumer class and report it via RxJavaPlugins.onError.
reportMoreProduced(long) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Reports to the plugin error handler that there were more values produced than requested, which is a sign of internal backpressure handling bug.
reportSubscriptionSet() - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Reports that the subscription is already set to the RxJavaPlugins error handler, which is an indication of a onSubscribe management bug.
request(long) - Method in class io.reactivex.internal.observers.SubscriberCompletableObserver
 
request(long) - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.BlockingSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.BoundedSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.FutureSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.LambdaSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.StrictSubscriber
 
request(long) - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
request(long) - Method in class io.reactivex.internal.subscriptions.AsyncSubscription
 
request(long) - Method in class io.reactivex.internal.subscriptions.BooleanSubscription
 
request(long) - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
 
request(long) - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
request(long) - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
 
request(long) - Method in class io.reactivex.internal.subscriptions.SubscriptionArbiter
 
request(long) - Method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
 
request(long) - Method in enum io.reactivex.internal.util.EmptyComponent
 
request(Subscription, int) - Static method in class io.reactivex.internal.util.QueueDrainHelper
Requests Long.MAX_VALUE if prefetch is negative or the exact amount if prefetch is positive.
request(long) - Method in class io.reactivex.subscribers.DefaultSubscriber
Requests from the upstream Subscription.
request(long) - Method in class io.reactivex.subscribers.DisposableSubscriber
Requests the specified amount from the upstream if its Subscription is set via onSubscribe already.
request(long) - Method in class io.reactivex.subscribers.ResourceSubscriber
Request the specified amount of elements from upstream.
request(long) - Method in class io.reactivex.subscribers.SafeSubscriber
 
request(long) - Method in class io.reactivex.subscribers.SerializedSubscriber
 
request(long) - Method in class io.reactivex.subscribers.TestSubscriber
 
REQUEST_MAX - Static variable in class io.reactivex.internal.functions.Functions
 
requested() - Method in interface io.reactivex.FlowableEmitter
The current outstanding request amount.
requested() - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
requested(long) - Method in class io.reactivex.internal.subscribers.QueueDrainSubscriber
 
requested() - Method in interface io.reactivex.internal.util.QueueDrain
 
requestFusion(int) - Method in enum io.reactivex.internal.disposables.EmptyDisposable
 
requestFusion(int) - Method in interface io.reactivex.internal.fuseable.QueueFuseable
Request a fusion mode from the upstream.
requestFusion(int) - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
 
requestFusion(int) - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy.GroupBySubscriber
 
requestFusion(int) - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
requestFusion(int) - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
 
requestFusion(int) - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
requestFusion(int) - Method in class io.reactivex.internal.subscriptions.ScalarSubscription
 
requestMore(long) - Method in class io.reactivex.subscribers.TestSubscriber
Calls TestSubscriber.request(long) and returns this.
requestOne() - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
requireNonNull(T, String) - Static method in class io.reactivex.internal.functions.ObjectHelper
Verifies if the object is not null and returns it or throws a NullPointerException with the given message.
requireNonNull(long, String) - Static method in class io.reactivex.internal.functions.ObjectHelper
Deprecated.
this method should not be used as there is no need to check primitives for nullness.
reset() - Static method in class io.reactivex.plugins.RxJavaPlugins
Removes all handlers and resets to default behavior.
ResourceCompletableObserver - Class in io.reactivex.observers
An abstract CompletableObserver that allows asynchronous cancellation of its subscription and associated resources.
ResourceCompletableObserver() - Constructor for class io.reactivex.observers.ResourceCompletableObserver
 
ResourceMaybeObserver<T> - Class in io.reactivex.observers
An abstract MaybeObserver that allows asynchronous cancellation of its subscription and associated resources.
ResourceMaybeObserver() - Constructor for class io.reactivex.observers.ResourceMaybeObserver
 
ResourceObserver<T> - Class in io.reactivex.observers
An abstract Observer that allows asynchronous cancellation of its subscription and associated resources.
ResourceObserver() - Constructor for class io.reactivex.observers.ResourceObserver
 
ResourceSingleObserver<T> - Class in io.reactivex.observers
An abstract SingleObserver that allows asynchronous cancellation of its subscription and the associated resources.
ResourceSingleObserver() - Constructor for class io.reactivex.observers.ResourceSingleObserver
 
ResourceSubscriber<T> - Class in io.reactivex.subscribers
An abstract Subscriber that allows asynchronous cancellation of its subscription and associated resources.
ResourceSubscriber() - Constructor for class io.reactivex.subscribers.ResourceSubscriber
 
ResumeSingleObserver<T> - Class in io.reactivex.internal.observers
A SingleObserver implementation used for subscribing to the actual SingleSource and replace the current Disposable in a parent AtomicReference.
ResumeSingleObserver(AtomicReference<Disposable>, SingleObserver<? super T>) - Constructor for class io.reactivex.internal.observers.ResumeSingleObserver
 
retainAll(Collection<?>) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
retry() - Method in class io.reactivex.Completable
Returns a Completable that retries this Completable as long as it emits an onError event.
retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.Completable
Returns a Completable that retries this Completable in case of an error as long as the predicate returns true.
retry(long) - Method in class io.reactivex.Completable
Returns a Completable that when this Completable emits an error, retries at most the given number of times before giving up and emitting the last error.
retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.Completable
Returns a Completable that when this Completable emits an error, retries at most times or until the predicate returns false, whichever happens first and emitting the last error.
retry(Predicate<? super Throwable>) - Method in class io.reactivex.Completable
Returns a Completable that when this Completable emits an error, calls the given predicate with the latest exception to decide whether to resubscribe to this or not.
retry() - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, resubscribing to it if it calls onError (infinite retry count).
retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, resubscribing to it if it calls onError and the predicate returns true for that specific exception and retry count.
retry(long) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, resubscribing to it if it calls onError up to a specified number of retries.
retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.Flowable
Retries at most times or until the predicate returns false, whichever happens first.
retry(Predicate<? super Throwable>) - Method in class io.reactivex.Flowable
Retries the current Flowable if the predicate returns true.
retry() - Method in class io.reactivex.Maybe
Returns a Maybe that mirrors the source Maybe, resubscribing to it if it calls onError (infinite retry count).
retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.Maybe
Returns a Maybe that mirrors the source Maybe, resubscribing to it if it calls onError and the predicate returns true for that specific exception and retry count.
retry(long) - Method in class io.reactivex.Maybe
Returns a Maybe that mirrors the source Maybe, resubscribing to it if it calls onError up to a specified number of retries.
retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.Maybe
Retries at most times or until the predicate returns false, whichever happens first.
retry(Predicate<? super Throwable>) - Method in class io.reactivex.Maybe
Retries the current Maybe if it fails and the predicate returns true.
retry() - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, resubscribing to it if it calls onError (infinite retry count).
retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, resubscribing to it if it calls onError and the predicate returns true for that specific exception and retry count.
retry(long) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, resubscribing to it if it calls onError up to a specified number of retries.
retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.Observable
Retries at most times or until the predicate returns false, whichever happens first.
retry(Predicate<? super Throwable>) - Method in class io.reactivex.Observable
Retries the current Observable if the predicate returns true.
retry() - Method in class io.reactivex.Single
Repeatedly re-subscribes to the current Single indefinitely if it fails with an onError.
retry(long) - Method in class io.reactivex.Single
Repeatedly re-subscribe at most the specified times to the current Single if it fails with an onError.
retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.Single
Re-subscribe to the current Single if the given predicate returns true when the Single fails with an onError.
retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.Single
Repeatedly re-subscribe at most times or until the predicate returns false, whichever happens first if it fails with an onError.
retry(Predicate<? super Throwable>) - Method in class io.reactivex.Single
Re-subscribe to the current Single if the given predicate returns true when the Single fails with an onError.
retryUntil(BooleanSupplier) - Method in class io.reactivex.Flowable
Retries until the given stop function returns true.
retryUntil(BooleanSupplier) - Method in class io.reactivex.Maybe
Retries until the given stop function returns true.
retryUntil(BooleanSupplier) - Method in class io.reactivex.Observable
Retries until the given stop function returns true.
retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class io.reactivex.Completable
Returns a Completable which given a Publisher and when this Completable emits an error, delivers that error through a Flowable and the Publisher should signal a value indicating a retry in response or a terminal event indicating a termination.
retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the same values as the source Publisher with the exception of an onError.
retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class io.reactivex.Maybe
Returns a Maybe that emits the same values as the source Maybe with the exception of an onError.
retryWhen(Function<? super Observable<Throwable>, ? extends ObservableSource<?>>) - Method in class io.reactivex.Observable
Returns an Observable that emits the same values as the source ObservableSource with the exception of an onError.
retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class io.reactivex.Single
Re-subscribes to the current Single if and when the Publisher returned by the handler function signals a value.
roundToPowerOfTwo(int) - Static method in class io.reactivex.internal.util.Pow2
Find the next larger positive power of two value up from the given value.
run() - Method in interface io.reactivex.functions.Action
Runs the action and optionally throws a checked exception.
run() - Method in class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
run() - Method in class io.reactivex.internal.schedulers.ExecutorScheduler.ExecutorWorker
 
run() - Method in class io.reactivex.internal.schedulers.ScheduledDirectPeriodicTask
 
run() - Method in class io.reactivex.internal.schedulers.ScheduledRunnable
 
run() - Method in class io.reactivex.internal.util.BlockingIgnoringReceiver
 
run() - Method in enum io.reactivex.observers.BaseTestConsumer.TestWaitStrategy
 
runOn(Scheduler) - Method in class io.reactivex.parallel.ParallelFlowable
Specifies where each 'rail' will observe its incoming values with no work-stealing and default prefetch amount.
runOn(Scheduler, int) - Method in class io.reactivex.parallel.ParallelFlowable
Specifies where each 'rail' will observe its incoming values with possibly work-stealing and a given prefetch amount.
RxJavaPlugins - Class in io.reactivex.plugins
Utility class to inject handlers to certain standard RxJava operations.
RxThreadFactory - Class in io.reactivex.internal.schedulers
A ThreadFactory that counts how many threads have been created and given a prefix, sets the created Thread's name to prefix-count.
RxThreadFactory(String) - Constructor for class io.reactivex.internal.schedulers.RxThreadFactory
 
RxThreadFactory(String, int) - Constructor for class io.reactivex.internal.schedulers.RxThreadFactory
 
RxThreadFactory(String, int, boolean) - Constructor for class io.reactivex.internal.schedulers.RxThreadFactory
 

S

s - Variable in class io.reactivex.internal.observers.BasicFuseableObserver
The upstream subscription.
s - Variable in class io.reactivex.internal.observers.DeferredScalarObserver
The upstream disposable.
s - Variable in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
The upstream subscription.
s - Variable in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
The upstream subscription.
s - Variable in class io.reactivex.internal.subscribers.DeferredScalarSubscriber
The upstream subscription.
s - Variable in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
The upstream subscription.
SafeObserver<T> - Class in io.reactivex.observers
Wraps another Subscriber and ensures all onXXX methods conform the protocol (except the requirement for serialized access).
SafeObserver(Observer<? super T>) - Constructor for class io.reactivex.observers.SafeObserver
Constructs a SafeObserver by wrapping the given actual Observer.
safeSubscribe(Subscriber<? super T>) - Method in class io.reactivex.Flowable
Subscribes to the current Flowable and wraps the given Subscriber into a SafeSubscriber (if not already a SafeSubscriber) that deals with exceptions thrown by a misbehaving Subscriber (that doesn't follow the Reactive-Streams specification).
safeSubscribe(Observer<? super T>) - Method in class io.reactivex.Observable
Subscribes to the current Observable and wraps the given Observer into a SafeObserver (if not already a SafeObserver) that deals with exceptions thrown by a misbehaving Observer (that doesn't follow the Reactive-Streams specification).
SafeSubscriber<T> - Class in io.reactivex.subscribers
Wraps another Subscriber and ensures all onXXX methods conform the protocol (except the requirement for serialized access).
SafeSubscriber(Subscriber<? super T>) - Constructor for class io.reactivex.subscribers.SafeSubscriber
Constructs a SafeSubscriber by wrapping the given actual Subscriber.
sample(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the most recently emitted item (if any) emitted by the source Publisher within periodic time intervals.
sample(long, TimeUnit, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the most recently emitted item (if any) emitted by the source Publisher within periodic time intervals and optionally emit the very last upstream item when the upstream completes.
sample(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the most recently emitted item (if any) emitted by the source Publisher within periodic time intervals, where the intervals are defined on a particular Scheduler.
sample(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the most recently emitted item (if any) emitted by the source Publisher within periodic time intervals, where the intervals are defined on a particular Scheduler and optionally emit the very last upstream item when the upstream completes.
sample(Publisher<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that, when the specified sampler Publisher emits an item or completes, emits the most recently emitted item (if any) emitted by the source Publisher since the previous emission from the sampler Publisher.
sample(Publisher<U>, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that, when the specified sampler Publisher emits an item or completes, emits the most recently emitted item (if any) emitted by the source Publisher since the previous emission from the sampler Publisher and optionally emit the very last upstream item when the upstream or other Publisher complete.
sample(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits the most recently emitted item (if any) emitted by the source ObservableSource within periodic time intervals.
sample(long, TimeUnit, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits the most recently emitted item (if any) emitted by the source ObservableSource within periodic time intervals and optionally emit the very last upstream item when the upstream completes.
sample(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits the most recently emitted item (if any) emitted by the source ObservableSource within periodic time intervals, where the intervals are defined on a particular Scheduler.
sample(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits the most recently emitted item (if any) emitted by the source ObservableSource within periodic time intervals, where the intervals are defined on a particular Scheduler and optionally emit the very last upstream item when the upstream completes.
sample(ObservableSource<U>) - Method in class io.reactivex.Observable
Returns an Observable that, when the specified sampler ObservableSource emits an item or completes, emits the most recently emitted item (if any) emitted by the source ObservableSource since the previous emission from the sampler ObservableSource.
sample(ObservableSource<U>, boolean) - Method in class io.reactivex.Observable
Returns an Observable that, when the specified sampler ObservableSource emits an item or completes, emits the most recently emitted item (if any) emitted by the source ObservableSource since the previous emission from the sampler ObservableSource and optionally emit the very last upstream item when the upstream or other ObservableSource complete.
ScalarCallable<T> - Interface in io.reactivex.internal.fuseable
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.
ScalarDisposable(Observer<? super T>, T) - Constructor for class io.reactivex.internal.operators.observable.ObservableScalarXMap.ScalarDisposable
 
ScalarSubscription<T> - Class in io.reactivex.internal.subscriptions
A Subscription that holds a constant value and emits it only when requested.
ScalarSubscription(Subscriber<? super T>, T) - Constructor for class io.reactivex.internal.subscriptions.ScalarSubscription
 
scalarXMap(T, Function<? super T, ? extends Publisher<? extends U>>) - Static method in class io.reactivex.internal.operators.flowable.FlowableScalarXMap
Maps a scalar value into a Publisher and emits its values.
scalarXMap(T, Function<? super T, ? extends ObservableSource<? extends U>>) - Static method in class io.reactivex.internal.operators.observable.ObservableScalarXMap
Maps a scalar value into an Observable and emits its values.
scan(BiFunction<T, T, T>) - Method in class io.reactivex.Flowable
Returns a Flowable that applies a specified accumulator function to the first item emitted by a source Publisher, then feeds the result of that function along with the second item emitted by the source Publisher into the same function, and so on until all items have been emitted by the source Publisher, emitting the result of each of these iterations.
scan(R, BiFunction<R, ? super T, R>) - Method in class io.reactivex.Flowable
Returns a Flowable that applies a specified accumulator function to the first item emitted by a source Publisher and a seed value, then feeds the result of that function along with the second item emitted by the source Publisher into the same function, and so on until all items have been emitted by the source Publisher, emitting the result of each of these iterations.
scan(BiFunction<T, T, T>) - Method in class io.reactivex.Observable
Returns an Observable that applies a specified accumulator function to the first item emitted by a source ObservableSource, then feeds the result of that function along with the second item emitted by the source ObservableSource into the same function, and so on until all items have been emitted by the source ObservableSource, emitting the result of each of these iterations.
scan(R, BiFunction<R, ? super T, R>) - Method in class io.reactivex.Observable
Returns an Observable that applies a specified accumulator function to the first item emitted by a source ObservableSource and a seed value, then feeds the result of that function along with the second item emitted by the source ObservableSource into the same function, and so on until all items have been emitted by the source ObservableSource, emitting the result of each of these iterations.
scanWith(Callable<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.Flowable
Returns a Flowable that applies a specified accumulator function to the first item emitted by a source Publisher and a seed value, then feeds the result of that function along with the second item emitted by the source Publisher into the same function, and so on until all items have been emitted by the source Publisher, emitting the result of each of these iterations.
scanWith(Callable<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.Observable
Returns an Observable that applies a specified accumulator function to the first item emitted by a source ObservableSource and a seed value, then feeds the result of that function along with the second item emitted by the source ObservableSource into the same function, and so on until all items have been emitted by the source ObservableSource, emitting the result of each of these iterations.
schedule(Runnable) - Method in class io.reactivex.internal.schedulers.ExecutorScheduler.ExecutorWorker
 
schedule(Runnable, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.ExecutorScheduler.ExecutorWorker
 
schedule(Runnable) - Method in class io.reactivex.internal.schedulers.NewThreadWorker
 
schedule(Runnable, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.NewThreadWorker
 
schedule(Runnable) - Method in class io.reactivex.Scheduler.Worker
Schedules a Runnable for execution without any time delay.
schedule(Runnable, long, TimeUnit) - Method in class io.reactivex.Scheduler.Worker
Schedules an Runnable for execution at some point in the future specified by a time delay relative to the current time.
scheduleActual(Runnable, long, TimeUnit, DisposableContainer) - Method in class io.reactivex.internal.schedulers.NewThreadWorker
Wraps the given runnable into a ScheduledRunnable and schedules it on the underlying ScheduledExecutorService.
ScheduledDirectPeriodicTask - Class in io.reactivex.internal.schedulers
A Callable to be submitted to an ExecutorService that runs a Runnable action periodically and manages completion/cancellation.
ScheduledDirectPeriodicTask(Runnable) - Constructor for class io.reactivex.internal.schedulers.ScheduledDirectPeriodicTask
 
ScheduledDirectTask - Class in io.reactivex.internal.schedulers
A Callable to be submitted to an ExecutorService that runs a Runnable action and manages completion/cancellation.
ScheduledDirectTask(Runnable) - Constructor for class io.reactivex.internal.schedulers.ScheduledDirectTask
 
scheduleDirect(Runnable, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.ComputationScheduler
 
scheduleDirect(Runnable) - Method in class io.reactivex.internal.schedulers.ExecutorScheduler
 
scheduleDirect(Runnable, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.ExecutorScheduler
 
scheduleDirect(Runnable) - Method in class io.reactivex.internal.schedulers.ImmediateThinScheduler
 
scheduleDirect(Runnable, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.ImmediateThinScheduler
 
scheduleDirect(Runnable, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.NewThreadWorker
Schedules the given runnable on the underlying executor directly and returns its future wrapped into a Disposable.
scheduleDirect(Runnable, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.SingleScheduler
 
scheduleDirect(Runnable) - Method in class io.reactivex.internal.schedulers.TrampolineScheduler
 
scheduleDirect(Runnable, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.TrampolineScheduler
 
scheduleDirect(Runnable) - Method in class io.reactivex.Scheduler
Schedules the given task on this Scheduler without any time delay.
scheduleDirect(Runnable, long, TimeUnit) - Method in class io.reactivex.Scheduler
Schedules the execution of the given task with the given time delay.
ScheduledRunnable - Class in io.reactivex.internal.schedulers
 
ScheduledRunnable(Runnable, DisposableContainer) - Constructor for class io.reactivex.internal.schedulers.ScheduledRunnable
Creates a ScheduledRunnable by wrapping the given action and setting up the optional parent.
schedulePeriodically(Runnable, long, long, TimeUnit) - Method in class io.reactivex.Scheduler.Worker
Schedules a periodic execution of the given task with the given initial time delay and repeat period.
schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.ComputationScheduler
 
schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.ExecutorScheduler
 
schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.ImmediateThinScheduler
 
schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.NewThreadWorker
Schedules the given runnable periodically on the underlying executor directly and returns its future wrapped into a Disposable.
schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class io.reactivex.internal.schedulers.SingleScheduler
 
schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class io.reactivex.Scheduler
Schedules a periodic execution of the given task with the given initial time delay and repeat period.
Scheduler - Class in io.reactivex
A Scheduler is an object that specifies an API for scheduling units of work provided in the form of Runnables 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() - Constructor for class io.reactivex.Scheduler
 
Scheduler.Worker - Class in io.reactivex
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 - Interface in io.reactivex.internal.schedulers
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 - Interface in io.reactivex.internal.schedulers
SchedulerPoolFactory - Class in io.reactivex.internal.schedulers
Manages the creating of ScheduledExecutorServices and sets up purging.
SchedulerRunnableIntrospection - Interface in io.reactivex.schedulers
Interface to indicate the implementor class wraps a Runnable that can be accessed via SchedulerRunnableIntrospection.getWrappedRunnable().
Schedulers - Class in io.reactivex.schedulers
Static factory methods for returning standard Scheduler instances.
SchedulerSupport - Annotation Type in io.reactivex.annotations
Indicates what kind of scheduler the class or method uses.
SchedulerWhen - Class in io.reactivex.internal.schedulers
Allows the use of operators for controlling the timing around when actions scheduled on workers are actually done.
SchedulerWhen(Function<Flowable<Flowable<Completable>>, Completable>, Scheduler) - Constructor for class io.reactivex.internal.schedulers.SchedulerWhen
 
sequenceEqual(Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.Flowable
Returns a Single that emits a Boolean value that indicates whether two Publisher sequences are the same by comparing the items emitted by each Publisher pairwise.
sequenceEqual(Publisher<? extends T>, Publisher<? extends T>, BiPredicate<? super T, ? super T>) - Static method in class io.reactivex.Flowable
Returns a Single that emits a Boolean value that indicates whether two Publisher sequences are the same by comparing the items emitted by each Publisher pairwise based on the results of a specified equality function.
sequenceEqual(Publisher<? extends T>, Publisher<? extends T>, BiPredicate<? super T, ? super T>, int) - Static method in class io.reactivex.Flowable
Returns a Single that emits a Boolean value that indicates whether two Publisher sequences are the same by comparing the items emitted by each Publisher pairwise based on the results of a specified equality function.
sequenceEqual(Publisher<? extends T>, Publisher<? extends T>, int) - Static method in class io.reactivex.Flowable
Returns a Single that emits a Boolean value that indicates whether two Publisher sequences are the same by comparing the items emitted by each Publisher pairwise.
sequenceEqual(MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.Maybe
Returns a Single that emits a Boolean value that indicates whether two MaybeSource sequences are the same by comparing the items emitted by each MaybeSource pairwise.
sequenceEqual(MaybeSource<? extends T>, MaybeSource<? extends T>, BiPredicate<? super T, ? super T>) - Static method in class io.reactivex.Maybe
Returns a Single that emits a Boolean value that indicates whether two MaybeSources are the same by comparing the items emitted by each MaybeSource pairwise based on the results of a specified equality function.
sequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.Observable
Returns a Single that emits a Boolean value that indicates whether two ObservableSource sequences are the same by comparing the items emitted by each ObservableSource pairwise.
sequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>, BiPredicate<? super T, ? super T>) - Static method in class io.reactivex.Observable
Returns a Single that emits a Boolean value that indicates whether two ObservableSource sequences are the same by comparing the items emitted by each ObservableSource pairwise based on the results of a specified equality function.
sequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>, BiPredicate<? super T, ? super T>, int) - Static method in class io.reactivex.Observable
Returns a Single that emits a Boolean value that indicates whether two ObservableSource sequences are the same by comparing the items emitted by each ObservableSource pairwise based on the results of a specified equality function.
sequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>, int) - Static method in class io.reactivex.Observable
Returns a Single that emits a Boolean value that indicates whether two ObservableSource sequences are the same by comparing the items emitted by each ObservableSource pairwise.
sequential() - Method in class io.reactivex.parallel.ParallelFlowable
Merges the values from each 'rail' in a round-robin or same-order fashion and exposes it as a regular Publisher sequence, running with a default prefetch value for the rails.
sequential(int) - Method in class io.reactivex.parallel.ParallelFlowable
Merges the values from each 'rail' in a round-robin or same-order fashion and exposes it as a regular Publisher sequence, running with a give prefetch value for the rails.
sequentialDelayError() - Method in class io.reactivex.parallel.ParallelFlowable
Merges the values from each 'rail' in a round-robin or same-order fashion and exposes it as a regular Flowable sequence, running with a default prefetch value for the rails and delaying errors from all rails till all terminate.
sequentialDelayError(int) - Method in class io.reactivex.parallel.ParallelFlowable
Merges the values from each 'rail' in a round-robin or same-order fashion and exposes it as a regular Publisher sequence, running with a give prefetch value for the rails and delaying errors from all rails till all terminate.
SequentialDisposable - Class in io.reactivex.internal.disposables
A Disposable container that allows updating/replacing a Disposable atomically and with respect of disposing the container itself.
SequentialDisposable() - Constructor for class io.reactivex.internal.disposables.SequentialDisposable
Constructs an empty SequentialDisposable.
SequentialDisposable(Disposable) - Constructor for class io.reactivex.internal.disposables.SequentialDisposable
Construct a SequentialDisposable with the initial Disposable provided.
SerialDisposable - Class in io.reactivex.disposables
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.
SerialDisposable() - Constructor for class io.reactivex.disposables.SerialDisposable
Constructs an empty SerialDisposable.
SerialDisposable(Disposable) - Constructor for class io.reactivex.disposables.SerialDisposable
Constructs a SerialDisposable with the given initial Disposable instance.
serialize() - Method in class io.reactivex.Flowable
Forces a Publisher's emissions and notifications to be serialized and for it to obey the Publisher contract in other ways.
serialize() - Method in interface io.reactivex.FlowableEmitter
Ensures that calls to onNext, onError and onComplete are properly serialized.
serialize() - Method in class io.reactivex.Observable
Forces an ObservableSource's emissions and notifications to be serialized and for it to obey the ObservableSource contract in other ways.
serialize() - Method in interface io.reactivex.ObservableEmitter
Ensures that calls to onNext, onError and onComplete are properly serialized.
SerializedObserver<T> - Class in io.reactivex.observers
Serializes access to the onNext, onError and onComplete methods of another Observer.
SerializedObserver(Observer<? super T>) - Constructor for class io.reactivex.observers.SerializedObserver
Construct a SerializedObserver by wrapping the given actual Observer.
SerializedObserver(Observer<? super T>, boolean) - Constructor for class io.reactivex.observers.SerializedObserver
Construct a SerializedObserver by wrapping the given actual Observer and optionally delaying the errors till all regular values have been emitted from the internal buffer.
SerializedSubscriber<T> - Class in io.reactivex.subscribers
Serializes access to the onNext, onError and onComplete methods of another Subscriber.
SerializedSubscriber(Subscriber<? super T>) - Constructor for class io.reactivex.subscribers.SerializedSubscriber
Construct a SerializedSubscriber by wrapping the given actual Subscriber.
SerializedSubscriber(Subscriber<? super T>, boolean) - Constructor for class io.reactivex.subscribers.SerializedSubscriber
Construct a SerializedSubscriber by wrapping the given actual Observer and optionally delaying the errors till all regular values have been emitted from the internal buffer.
set(Disposable) - Method in class io.reactivex.disposables.SerialDisposable
Atomically: set the next disposable on this container and dispose the previous one (if any) or dispose next if the container has been disposed.
set(AtomicReference<Disposable>, Disposable) - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Atomically sets the field and disposes the old contents.
set(AtomicReference<Subscription>, Subscription) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Atomically sets the subscription on the field and cancels the previous subscription if any.
set(int, T) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
setCancellable(Cancellable) - Method in interface io.reactivex.CompletableEmitter
Sets a Cancellable on this emitter; any previous Disposable or Cancellation will be disposed/cancelled.
setCancellable(Cancellable) - Method in interface io.reactivex.FlowableEmitter
Sets a Cancellable on this emitter; any previous Disposable or Cancellation will be disposed/cancelled.
setCancellable(Cancellable) - Method in interface io.reactivex.MaybeEmitter
Sets a Cancellable on this emitter; any previous Disposable or Cancellation will be unsubscribed/cancelled.
setCancellable(Cancellable) - Method in interface io.reactivex.ObservableEmitter
Sets a Cancellable on this emitter; any previous Disposable or Cancellation will be unsubscribed/cancelled.
setCancellable(Cancellable) - Method in interface io.reactivex.SingleEmitter
Sets a Cancellable on this emitter; any previous Disposable or Cancellation will be unsubscribed/cancelled.
setComputationSchedulerHandler(Function<? super Scheduler, ? extends Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setDisposable(Disposable) - Method in interface io.reactivex.CompletableEmitter
Sets a Disposable on this emitter; any previous Disposable or Cancellation will be disposed/cancelled.
setDisposable(Disposable) - Method in interface io.reactivex.FlowableEmitter
Sets a Disposable on this emitter; any previous Disposable or Cancellation will be disposed/cancelled.
setDisposable(Disposable) - Method in interface io.reactivex.MaybeEmitter
Sets a Disposable on this emitter; any previous Disposable or Cancellation will be unsubscribed/cancelled.
setDisposable(Disposable) - Method in interface io.reactivex.ObservableEmitter
Sets a Disposable on this emitter; any previous Disposable or Cancellation will be unsubscribed/cancelled.
setDisposable(Disposable) - Method in interface io.reactivex.SingleEmitter
Sets a Disposable on this emitter; any previous Disposable or Cancellation will be unsubscribed/cancelled.
setDone() - Method in class io.reactivex.internal.observers.InnerQueuedObserver
 
setDone() - Method in class io.reactivex.internal.subscribers.InnerQueuedSubscriber
 
setErrorHandler(Consumer<? super Throwable>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setFailOnNonBlockingScheduler(boolean) - Static method in class io.reactivex.plugins.RxJavaPlugins
Enables or disables the blockingX operators to fail with an IllegalStateException on a non-blocking scheduler such as computation or single.
setFirst(T) - Method in class io.reactivex.internal.util.AppendOnlyLinkedArrayList
Set a value as the first element of the list.
setFuture(Future<?>) - Method in class io.reactivex.internal.schedulers.ScheduledRunnable
 
setInitComputationSchedulerHandler(Function<? super Callable<Scheduler>, ? extends Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setInitIoSchedulerHandler(Function<? super Callable<Scheduler>, ? extends Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setInitNewThreadSchedulerHandler(Function<? super Callable<Scheduler>, ? extends Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setInitSingleSchedulerHandler(Function<? super Callable<Scheduler>, ? extends Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setIoSchedulerHandler(Function<? super Scheduler, ? extends Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setNewThreadSchedulerHandler(Function<? super Scheduler, ? extends Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnBeforeBlocking(BooleanSupplier) - Static method in class io.reactivex.plugins.RxJavaPlugins
Set the handler that is called when an operator attempts a blocking await; the handler should return true to prevent the blocking and to signal an IllegalStateException instead.
setOnce(AtomicReference<Disposable>, Disposable) - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Atomically sets the field to the given non-null Disposable and returns true or returns false if the field is non-null.
setOnce(AtomicReference<Subscription>, Subscription) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Atomically sets the subscription on the field if it is still null.
setOnce(AtomicReference<Subscription>, Subscription, long) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Atomically sets the subscription on the field if it is still null and issues a positive request to the given Subscription.
setOnce(AtomicReference<Disposable>, Disposable, Class<?>) - Static method in class io.reactivex.internal.util.EndConsumerHelper
Atomically updates the target upstream AtomicReference from null to the non-null next Disposable, otherwise disposes next and reports a ProtocolViolationException if the AtomicReference doesn't contain the shared disposed indicator.
setOnce(AtomicReference<Subscription>, Subscription, Class<?>) - Static method in class io.reactivex.internal.util.EndConsumerHelper
Atomically updates the target upstream AtomicReference from null to the non-null next Subscription, otherwise cancels next and reports a ProtocolViolationException if the AtomicReference doesn't contain the shared cancelled indicator.
setOnCompletableAssembly(Function<? super Completable, ? extends Completable>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnCompletableSubscribe(BiFunction<? super Completable, ? super CompletableObserver, ? extends CompletableObserver>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnConnectableFlowableAssembly(Function<? super ConnectableFlowable, ? extends ConnectableFlowable>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnConnectableObservableAssembly(Function<? super ConnectableObservable, ? extends ConnectableObservable>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnFlowableAssembly(Function<? super Flowable, ? extends Flowable>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnFlowableSubscribe(BiFunction<? super Flowable, ? super Subscriber, ? extends Subscriber>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnMaybeAssembly(Function<? super Maybe, ? extends Maybe>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnMaybeSubscribe(BiFunction<? super Maybe, MaybeObserver, ? extends MaybeObserver>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnObservableAssembly(Function<? super Observable, ? extends Observable>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnObservableSubscribe(BiFunction<? super Observable, ? super Observer, ? extends Observer>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnParallelAssembly(Function<? super ParallelFlowable, ? extends ParallelFlowable>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnSingleAssembly(Function<? super Single, ? extends Single>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setOnSingleSubscribe(BiFunction<? super Single, ? super SingleObserver, ? extends SingleObserver>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setResource(int, Disposable) - Method in class io.reactivex.internal.disposables.ArrayCompositeDisposable
Sets the resource at the specified index and disposes the old resource.
setResource(Disposable) - Method in class io.reactivex.internal.operators.observable.ObserverResourceWrapper
 
setResource(Disposable) - Method in class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
setResource(int, Subscription) - Method in class io.reactivex.internal.subscriptions.ArrayCompositeSubscription
Sets the resource at the specified index and disposes the old resource.
setResource(Disposable) - Method in class io.reactivex.internal.subscriptions.AsyncSubscription
Sets a new resource and disposes the currently held resource.
setScheduleHandler(Function<? super Runnable, ? extends Runnable>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setSingleSchedulerHandler(Function<? super Scheduler, ? extends Scheduler>) - Static method in class io.reactivex.plugins.RxJavaPlugins
Sets the specific hook function.
setSubscription(Subscription) - Method in class io.reactivex.internal.subscriptions.AsyncSubscription
Sets the given subscription if there isn't any subscription held.
setSubscription(Subscription) - Method in class io.reactivex.internal.subscriptions.SubscriptionArbiter
Atomically sets a new subscription.
share() - Method in class io.reactivex.Flowable
Returns a new Publisher that multicasts (and shares a single subscription to) the original Publisher.
share() - Method in class io.reactivex.Observable
Returns a new ObservableSource that multicasts (and shares a single subscription to) the original ObservableSource.
shutdown() - Method in class io.reactivex.internal.schedulers.ComputationScheduler
 
shutdown() - Method in class io.reactivex.internal.schedulers.IoScheduler
 
shutdown() - Method in class io.reactivex.internal.schedulers.NewThreadWorker
Shuts down the underlying executor in a non-interrupting fashion.
shutdown() - Static method in class io.reactivex.internal.schedulers.SchedulerPoolFactory
Stops the purge thread.
shutdown() - Method in class io.reactivex.internal.schedulers.SingleScheduler
 
shutdown() - Method in class io.reactivex.Scheduler
Instructs the Scheduler instance to stop threads, stop accepting tasks on any outstanding Scheduler.Worker instances and clean up any associated resources with this Scheduler.
shutdown() - Static method in class io.reactivex.schedulers.Schedulers
Shuts down the standard Schedulers.
simpleBiGenerator(BiConsumer<S, Emitter<T>>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
simpleBiGenerator(BiConsumer<S, Emitter<T>>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
simpleGenerator(Consumer<Emitter<T>>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
simpleGenerator(Consumer<Emitter<T>>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
SimplePlainQueue<T> - Interface in io.reactivex.internal.fuseable
Override of the SimpleQueue interface with no throws Exception on poll().
SimpleQueue<T> - Interface in io.reactivex.internal.fuseable
A minimalist queue interface without the method bloat of java.util.Collection and java.util.Queue.
SINGLE - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
The operator/class runs on RxJava's single scheduler or takes timing information from it.
single(T) - Method in class io.reactivex.Flowable
Returns a Single that emits the single item emitted by the source Publisher, if that Publisher emits only a single item, or a default item if the source Publisher emits no items.
single(T) - Method in class io.reactivex.Observable
Returns a Single that emits the single item emitted by this Observable, if this Observable emits only a single item, or a default item if the source ObservableSource emits no items.
single() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, shared, single-thread-backed Scheduler instance for work requiring strongly-sequential execution on the same background thread.
Single<T> - Class in io.reactivex
The Single class implements the Reactive Pattern for a single value response.
Single() - Constructor for class io.reactivex.Single
 
SingleAmb<T> - Class in io.reactivex.internal.operators.single
 
SingleAmb(SingleSource<? extends T>[], Iterable<? extends SingleSource<? extends T>>) - Constructor for class io.reactivex.internal.operators.single.SingleAmb
 
SingleCache<T> - Class in io.reactivex.internal.operators.single
 
SingleCache(SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.single.SingleCache
 
SingleContains<T> - Class in io.reactivex.internal.operators.single
 
SingleContains(SingleSource<T>, Object, BiPredicate<Object, Object>) - Constructor for class io.reactivex.internal.operators.single.SingleContains
 
SingleConverter<T,R> - Interface in io.reactivex
Convenience interface and callback used by the Single.as(io.reactivex.SingleConverter<T, ? extends R>) operator to turn a Single into another value fluently.
SingleCreate<T> - Class in io.reactivex.internal.operators.single
 
SingleCreate(SingleOnSubscribe<T>) - Constructor for class io.reactivex.internal.operators.single.SingleCreate
 
SingleDefer<T> - Class in io.reactivex.internal.operators.single
 
SingleDefer(Callable<? extends SingleSource<? extends T>>) - Constructor for class io.reactivex.internal.operators.single.SingleDefer
 
SingleDelay<T> - Class in io.reactivex.internal.operators.single
 
SingleDelay(SingleSource<? extends T>, long, TimeUnit, Scheduler, boolean) - Constructor for class io.reactivex.internal.operators.single.SingleDelay
 
SingleDelayWithCompletable<T> - Class in io.reactivex.internal.operators.single
 
SingleDelayWithCompletable(SingleSource<T>, CompletableSource) - Constructor for class io.reactivex.internal.operators.single.SingleDelayWithCompletable
 
SingleDelayWithObservable<T,U> - Class in io.reactivex.internal.operators.single
 
SingleDelayWithObservable(SingleSource<T>, ObservableSource<U>) - Constructor for class io.reactivex.internal.operators.single.SingleDelayWithObservable
 
SingleDelayWithPublisher<T,U> - Class in io.reactivex.internal.operators.single
 
SingleDelayWithPublisher(SingleSource<T>, Publisher<U>) - Constructor for class io.reactivex.internal.operators.single.SingleDelayWithPublisher
 
SingleDelayWithSingle<T,U> - Class in io.reactivex.internal.operators.single
 
SingleDelayWithSingle(SingleSource<T>, SingleSource<U>) - Constructor for class io.reactivex.internal.operators.single.SingleDelayWithSingle
 
SingleDetach<T> - Class in io.reactivex.internal.operators.single
Breaks the references between the upstream and downstream when the Maybe terminates.
SingleDetach(SingleSource<T>) - Constructor for class io.reactivex.internal.operators.single.SingleDetach
 
SingleDoAfterSuccess<T> - Class in io.reactivex.internal.operators.single
Calls a consumer after pushing the current item to the downstream.
SingleDoAfterSuccess(SingleSource<T>, Consumer<? super T>) - Constructor for class io.reactivex.internal.operators.single.SingleDoAfterSuccess
 
SingleDoAfterTerminate<T> - Class in io.reactivex.internal.operators.single
Calls an action after pushing the current item or an error to the downstream.
SingleDoAfterTerminate(SingleSource<T>, Action) - Constructor for class io.reactivex.internal.operators.single.SingleDoAfterTerminate
 
SingleDoFinally<T> - Class in io.reactivex.internal.operators.single
Execute an action after an onSuccess, onError or a dispose event.
SingleDoFinally(SingleSource<T>, Action) - Constructor for class io.reactivex.internal.operators.single.SingleDoFinally
 
SingleDoOnDispose<T> - Class in io.reactivex.internal.operators.single
 
SingleDoOnDispose(SingleSource<T>, Action) - Constructor for class io.reactivex.internal.operators.single.SingleDoOnDispose
 
SingleDoOnError<T> - Class in io.reactivex.internal.operators.single
 
SingleDoOnError(SingleSource<T>, Consumer<? super Throwable>) - Constructor for class io.reactivex.internal.operators.single.SingleDoOnError
 
SingleDoOnEvent<T> - Class in io.reactivex.internal.operators.single
 
SingleDoOnEvent(SingleSource<T>, BiConsumer<? super T, ? super Throwable>) - Constructor for class io.reactivex.internal.operators.single.SingleDoOnEvent
 
SingleDoOnSubscribe<T> - Class in io.reactivex.internal.operators.single
Calls a callback when the upstream calls onSubscribe with a disposable.
SingleDoOnSubscribe(SingleSource<T>, Consumer<? super Disposable>) - Constructor for class io.reactivex.internal.operators.single.SingleDoOnSubscribe
 
SingleDoOnSuccess<T> - Class in io.reactivex.internal.operators.single
 
SingleDoOnSuccess(SingleSource<T>, Consumer<? super T>) - Constructor for class io.reactivex.internal.operators.single.SingleDoOnSuccess
 
singleElement() - Method in class io.reactivex.Flowable
Returns a Maybe that completes if this Flowable is empty, signals one item if this Flowable signals exactly one item or signals an IllegalArgumentException if this Flowable signals more than one item.
singleElement() - Method in class io.reactivex.Observable
Returns a Maybe that completes if this Observable is empty or emits the single item emitted by this Observable, or signals an IllegalArgumentException if this Observable emits more than one item.
SingleEmitter<T> - Interface in io.reactivex
Abstraction over an RxJava SingleObserver that allows associating a resource with it.
SingleEquals<T> - Class in io.reactivex.internal.operators.single
 
SingleEquals(SingleSource<? extends T>, SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.single.SingleEquals
 
SingleError<T> - Class in io.reactivex.internal.operators.single
 
SingleError(Callable<? extends Throwable>) - Constructor for class io.reactivex.internal.operators.single.SingleError
 
SingleFlatMap<T,R> - Class in io.reactivex.internal.operators.single
 
SingleFlatMap(SingleSource<? extends T>, Function<? super T, ? extends SingleSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.single.SingleFlatMap
 
SingleFlatMapCompletable<T> - Class in io.reactivex.internal.operators.single
Maps the success value of the source SingleSource into a Completable.
SingleFlatMapCompletable(SingleSource<T>, Function<? super T, ? extends CompletableSource>) - Constructor for class io.reactivex.internal.operators.single.SingleFlatMapCompletable
 
SingleFlatMapIterableFlowable<T,R> - Class in io.reactivex.internal.operators.single
Maps a success value into an Iterable and streams it back as a Flowable.
SingleFlatMapIterableFlowable(SingleSource<T>, Function<? super T, ? extends Iterable<? extends R>>) - Constructor for class io.reactivex.internal.operators.single.SingleFlatMapIterableFlowable
 
SingleFlatMapIterableObservable<T,R> - Class in io.reactivex.internal.operators.single
Maps a success value into an Iterable and streams it back as an Observable.
SingleFlatMapIterableObservable(SingleSource<T>, Function<? super T, ? extends Iterable<? extends R>>) - Constructor for class io.reactivex.internal.operators.single.SingleFlatMapIterableObservable
 
SingleFlatMapMaybe<T,R> - Class in io.reactivex.internal.operators.single
 
SingleFlatMapMaybe(SingleSource<? extends T>, Function<? super T, ? extends MaybeSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.single.SingleFlatMapMaybe
 
SingleFlatMapObservable<T,R> - Class in io.reactivex.internal.operators.mixed
Maps the success value of a Single onto an ObservableSource and relays its signals to the downstream observer.
SingleFlatMapObservable(SingleSource<T>, Function<? super T, ? extends ObservableSource<? extends R>>) - Constructor for class io.reactivex.internal.operators.mixed.SingleFlatMapObservable
 
SingleFlatMapPublisher<T,R> - Class in io.reactivex.internal.operators.single
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(SingleSource<T>, Function<? super T, ? extends Publisher<? extends R>>) - Constructor for class io.reactivex.internal.operators.single.SingleFlatMapPublisher
 
SingleFromCallable<T> - Class in io.reactivex.internal.operators.single
 
SingleFromCallable(Callable<? extends T>) - Constructor for class io.reactivex.internal.operators.single.SingleFromCallable
 
SingleFromPublisher<T> - Class in io.reactivex.internal.operators.single
 
SingleFromPublisher(Publisher<? extends T>) - Constructor for class io.reactivex.internal.operators.single.SingleFromPublisher
 
SingleFromUnsafeSource<T> - Class in io.reactivex.internal.operators.single
 
SingleFromUnsafeSource(SingleSource<T>) - Constructor for class io.reactivex.internal.operators.single.SingleFromUnsafeSource
 
SingleHide<T> - Class in io.reactivex.internal.operators.single
 
SingleHide(SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.single.SingleHide
 
SingleInternalHelper - Class in io.reactivex.internal.operators.single
Helper utility class to support Single with inner classes.
SingleJust<T> - Class in io.reactivex.internal.operators.single
 
SingleJust(T) - Constructor for class io.reactivex.internal.operators.single.SingleJust
 
SingleLift<T,R> - Class in io.reactivex.internal.operators.single
 
SingleLift(SingleSource<T>, SingleOperator<? extends R, ? super T>) - Constructor for class io.reactivex.internal.operators.single.SingleLift
 
SingleMap<T,R> - Class in io.reactivex.internal.operators.single
 
SingleMap(SingleSource<? extends T>, Function<? super T, ? extends R>) - Constructor for class io.reactivex.internal.operators.single.SingleMap
 
SingleNever - Class in io.reactivex.internal.operators.single
 
SingleObserveOn<T> - Class in io.reactivex.internal.operators.single
 
SingleObserveOn(SingleSource<T>, Scheduler) - Constructor for class io.reactivex.internal.operators.single.SingleObserveOn
 
SingleObserver<T> - Interface in io.reactivex
Provides a mechanism for receiving push-based notification of a single value or an error.
SingleOnErrorReturn<T> - Class in io.reactivex.internal.operators.single
 
SingleOnErrorReturn(SingleSource<? extends T>, Function<? super Throwable, ? extends T>, T) - Constructor for class io.reactivex.internal.operators.single.SingleOnErrorReturn
 
SingleOnSubscribe<T> - Interface in io.reactivex
A functional interface that has a subscribe() method that receives an instance of a SingleEmitter instance that allows pushing an event in a cancellation-safe manner.
SingleOperator<Downstream,Upstream> - Interface in io.reactivex
Interface to map/wrap a downstream observer to an upstream observer.
singleOrError() - Method in class io.reactivex.Flowable
Returns a Single that emits the single item emitted by this Flowable, if this Flowable emits only a single item, otherwise if this Flowable completes without emitting any items a NoSuchElementException will be signaled and if this Flowable emits more than one item, an IllegalArgumentException will be signaled.
singleOrError() - Method in class io.reactivex.Observable
Returns a Single that emits the single item emitted by this Observable if this Observable emits only a single item, otherwise if this Observable completes without emitting any items or emits more than one item a NoSuchElementException or IllegalArgumentException will be signalled respectively.
SinglePostCompleteSubscriber<T,R> - Class in io.reactivex.internal.subscribers
Relays signals from upstream according to downstream requests and allows signalling a final value followed by onComplete in a backpressure-aware manner.
SinglePostCompleteSubscriber(Subscriber<? super R>) - Constructor for class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
 
SingleResumeNext<T> - Class in io.reactivex.internal.operators.single
 
SingleResumeNext(SingleSource<? extends T>, Function<? super Throwable, ? extends SingleSource<? extends T>>) - Constructor for class io.reactivex.internal.operators.single.SingleResumeNext
 
SingleScheduler - Class in io.reactivex.internal.schedulers
A scheduler with a shared, single threaded underlying ScheduledExecutorService.
SingleScheduler() - Constructor for class io.reactivex.internal.schedulers.SingleScheduler
 
SingleScheduler(ThreadFactory) - Constructor for class io.reactivex.internal.schedulers.SingleScheduler
 
SingleSource<T> - Interface in io.reactivex
Represents a basic Single source base interface, consumable via an SingleObserver.
SingleSubject<T> - Class in io.reactivex.subjects
Represents a hot Single-like source and consumer of events similar to Subjects.
SingleSubscribeOn<T> - Class in io.reactivex.internal.operators.single
 
SingleSubscribeOn(SingleSource<? extends T>, Scheduler) - Constructor for class io.reactivex.internal.operators.single.SingleSubscribeOn
 
SingleTakeUntil<T,U> - Class in io.reactivex.internal.operators.single
Signals the events of the source Single or signals a CancellationException if the other Publisher signalled first.
SingleTakeUntil(SingleSource<T>, Publisher<U>) - Constructor for class io.reactivex.internal.operators.single.SingleTakeUntil
 
SingleTimeout<T> - Class in io.reactivex.internal.operators.single
 
SingleTimeout(SingleSource<T>, long, TimeUnit, Scheduler, SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.single.SingleTimeout
 
SingleTimer - Class in io.reactivex.internal.operators.single
Signals a 0L after the specified delay.
SingleTimer(long, TimeUnit, Scheduler) - Constructor for class io.reactivex.internal.operators.single.SingleTimer
 
SingleToFlowable<T> - Class in io.reactivex.internal.operators.single
Wraps a Single and exposes it as a Flowable.
SingleToFlowable(SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.single.SingleToFlowable
 
SingleToObservable<T> - Class in io.reactivex.internal.operators.single
Wraps a Single and exposes it as an Observable.
SingleToObservable(SingleSource<? extends T>) - Constructor for class io.reactivex.internal.operators.single.SingleToObservable
 
SingleTransformer<Upstream,Downstream> - Interface in io.reactivex
Interface to compose Singles.
SingleUnsubscribeOn<T> - Class in io.reactivex.internal.operators.single
Makes sure a dispose() call from downstream happens on the specified scheduler.
SingleUnsubscribeOn(SingleSource<T>, Scheduler) - Constructor for class io.reactivex.internal.operators.single.SingleUnsubscribeOn
 
SingleUsing<T,U> - Class in io.reactivex.internal.operators.single
 
SingleUsing(Callable<U>, Function<? super U, ? extends SingleSource<? extends T>>, Consumer<? super U>, boolean) - Constructor for class io.reactivex.internal.operators.single.SingleUsing
 
SingleZipArray<T,R> - Class in io.reactivex.internal.operators.single
 
SingleZipArray(SingleSource<? extends T>[], Function<? super Object[], ? extends R>) - Constructor for class io.reactivex.internal.operators.single.SingleZipArray
 
SingleZipIterable<T,R> - Class in io.reactivex.internal.operators.single
 
SingleZipIterable(Iterable<? extends SingleSource<? extends T>>, Function<? super Object[], ? extends R>) - Constructor for class io.reactivex.internal.operators.single.SingleZipIterable
 
size() - Method in class io.reactivex.disposables.CompositeDisposable
Returns the number of currently held Disposables.
size() - Method in exception io.reactivex.exceptions.CompositeException
Returns the number of suppressed exceptions.
size() - Method in class io.reactivex.internal.queue.SpscLinkedArrayQueue
 
size() - Method in class io.reactivex.internal.schedulers.IoScheduler
 
size() - Method in class io.reactivex.internal.util.LinkedArrayList
Returns the total size of the list.
size() - Method in class io.reactivex.internal.util.OpenHashSet
 
size() - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
skip(long) - Method in class io.reactivex.Flowable
Returns a Flowable that skips the first count items emitted by the source Publisher and emits the remainder.
skip(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that skips values emitted by the source Publisher before a specified time window elapses.
skip(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that skips values emitted by the source Publisher before a specified time window on a specified Scheduler elapses.
skip(long) - Method in class io.reactivex.Observable
Returns an Observable that skips the first count items emitted by the source ObservableSource and emits the remainder.
skip(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that skips values emitted by the source ObservableSource before a specified time window elapses.
skip(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that skips values emitted by the source ObservableSource before a specified time window on a specified Scheduler elapses.
skipLast(int) - Method in class io.reactivex.Flowable
Returns a Flowable that drops a specified number of items from the end of the sequence emitted by the source Publisher.
skipLast(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that drops items emitted by the source Publisher during a specified time window before the source completes.
skipLast(long, TimeUnit, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that drops items emitted by the source Publisher during a specified time window before the source completes.
skipLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that drops items emitted by the source Publisher during a specified time window (defined on a specified scheduler) before the source completes.
skipLast(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that drops items emitted by the source Publisher during a specified time window (defined on a specified scheduler) before the source completes.
skipLast(long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.Flowable
Returns a Flowable that drops items emitted by the source Publisher during a specified time window (defined on a specified scheduler) before the source completes.
skipLast(int) - Method in class io.reactivex.Observable
Returns an Observable that drops a specified number of items from the end of the sequence emitted by the source ObservableSource.
skipLast(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that drops items emitted by the source ObservableSource during a specified time window before the source completes.
skipLast(long, TimeUnit, boolean) - Method in class io.reactivex.Observable
Returns an Observable that drops items emitted by the source ObservableSource during a specified time window before the source completes.
skipLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that drops items emitted by the source ObservableSource during a specified time window (defined on a specified scheduler) before the source completes.
skipLast(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Observable
Returns an Observable that drops items emitted by the source ObservableSource during a specified time window (defined on a specified scheduler) before the source completes.
skipLast(long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.Observable
Returns an Observable that drops items emitted by the source ObservableSource during a specified time window (defined on a specified scheduler) before the source completes.
skipUntil(Publisher<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that skips items emitted by the source Publisher until a second Publisher emits an item.
skipUntil(ObservableSource<U>) - Method in class io.reactivex.Observable
Returns an Observable that skips items emitted by the source ObservableSource until a second ObservableSource emits an item.
skipWhile(Predicate<? super T>) - Method in class io.reactivex.Flowable
Returns a Flowable that skips all items emitted by the source Publisher as long as a specified condition holds true, but emits all further source items as soon as the condition becomes false.
skipWhile(Predicate<? super T>) - Method in class io.reactivex.Observable
Returns an Observable that skips all items emitted by the source ObservableSource as long as a specified condition holds true, but emits all further source items as soon as the condition becomes false.
sorted() - Method in class io.reactivex.Flowable
Returns a Flowable that emits the events emitted by source Publisher, in a sorted order.
sorted(Comparator<? super T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the events emitted by source Publisher, in a sorted order based on a specified comparison function.
sorted() - Method in class io.reactivex.Observable
Returns an Observable that emits the events emitted by source ObservableSource, in a sorted order.
sorted(Comparator<? super T>) - Method in class io.reactivex.Observable
Returns an Observable that emits the events emitted by source ObservableSource, in a sorted order based on a specified comparison function.
sorted(Comparator<? super T>) - Method in class io.reactivex.parallel.ParallelFlowable
Sorts the 'rails' of this ParallelFlowable and returns a Publisher that sequentially picks the smallest next value from the rails.
sorted(Comparator<? super T>, int) - Method in class io.reactivex.parallel.ParallelFlowable
Sorts the 'rails' of this ParallelFlowable and returns a Publisher that sequentially picks the smallest next value from the rails.
SorterFunction<T> - Class in io.reactivex.internal.util
 
SorterFunction(Comparator<? super T>) - Constructor for class io.reactivex.internal.util.SorterFunction
 
source() - Method in interface io.reactivex.internal.fuseable.HasUpstreamCompletableSource
Returns the upstream source of this Completable.
source() - Method in interface io.reactivex.internal.fuseable.HasUpstreamMaybeSource
Returns the upstream source of this Maybe.
source() - Method in interface io.reactivex.internal.fuseable.HasUpstreamObservableSource
Returns the upstream source of this Observable.
source() - Method in interface io.reactivex.internal.fuseable.HasUpstreamPublisher
Returns the source Publisher.
source() - Method in interface io.reactivex.internal.fuseable.HasUpstreamSingleSource
Returns the upstream source of this Single.
source() - Method in class io.reactivex.internal.operators.flowable.FlowablePublish
 
source() - Method in class io.reactivex.internal.operators.flowable.FlowableReduceMaybe
 
source() - Method in class io.reactivex.internal.operators.flowable.FlowableReplay
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeContains
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeCount
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeFromCompletable
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeFromSingle
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeIsEmptySingle
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeSwitchIfEmptySingle
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeToFlowable
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeToObservable
 
source() - Method in class io.reactivex.internal.operators.maybe.MaybeToSingle
 
source() - Method in class io.reactivex.internal.operators.observable.ObservablePublish
 
source() - Method in class io.reactivex.internal.operators.observable.ObservableReplay
 
sourceMode - Variable in class io.reactivex.internal.observers.BasicFuseableObserver
Holds the established fusion mode of the upstream.
sourceMode - Variable in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
Holds the established fusion mode of the upstream.
sourceMode - Variable in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
Holds the established fusion mode of the upstream.
SpscArrayQueue<E> - Class in io.reactivex.internal.queue
A Single-Producer-Single-Consumer queue backed by a pre-allocated buffer.
SpscArrayQueue(int) - Constructor for class io.reactivex.internal.queue.SpscArrayQueue
 
SpscLinkedArrayQueue<T> - Class in io.reactivex.internal.queue
A single-producer single-consumer array-backed queue which can allocate new arrays in case the consumer is slower than the producer.
SpscLinkedArrayQueue(int) - Constructor for class io.reactivex.internal.queue.SpscLinkedArrayQueue
 
start() - Method in class io.reactivex.internal.schedulers.ComputationScheduler
 
start() - Method in class io.reactivex.internal.schedulers.IoScheduler
 
start() - Static method in class io.reactivex.internal.schedulers.SchedulerPoolFactory
Starts the purge thread if not already started.
start() - Method in class io.reactivex.internal.schedulers.SingleScheduler
 
start() - Method in class io.reactivex.processors.MulticastProcessor
Initializes this Processor by setting an upstream Subscription that ignores request amounts, uses a fixed buffer and allows using the onXXX and offer methods afterwards.
start() - Method in class io.reactivex.Scheduler
Allows the Scheduler instance to start threads and accept tasks on them.
start() - Static method in class io.reactivex.schedulers.Schedulers
Starts the standard Schedulers.
startUnbounded() - Method in class io.reactivex.processors.MulticastProcessor
Initializes this Processor by setting an upstream Subscription that ignores request amounts, uses an unbounded buffer and allows using the onXXX and offer methods afterwards.
startWith(CompletableSource) - Method in class io.reactivex.Completable
Returns a Completable which first runs the other Completable then this completable if the other completed normally.
startWith(Observable<T>) - Method in class io.reactivex.Completable
Returns an Observable which first delivers the events of the other Observable then runs this CompletableConsumable.
startWith(Publisher<T>) - Method in class io.reactivex.Completable
Returns a Flowable which first delivers the events of the other Publisher then runs this Completable.
startWith(Iterable<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items in a specified Iterable before it begins to emit items emitted by the source Publisher.
startWith(Publisher<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items in a specified Publisher before it begins to emit items emitted by the source Publisher.
startWith(T) - Method in class io.reactivex.Flowable
Returns a Flowable that emits a specified item before it begins to emit items emitted by the source Publisher.
startWith(Iterable<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that emits the items in a specified Iterable before it begins to emit items emitted by the source ObservableSource.
startWith(ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that emits the items in a specified ObservableSource before it begins to emit items emitted by the source ObservableSource.
startWith(T) - Method in class io.reactivex.Observable
Returns an Observable that emits a specified item before it begins to emit items emitted by the source ObservableSource.
startWithArray(T...) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the specified items before it begins to emit items emitted by the source Publisher.
startWithArray(T...) - Method in class io.reactivex.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source ObservableSource.
StrictSubscriber<T> - Class in io.reactivex.internal.subscribers
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).
StrictSubscriber(Subscriber<? super T>) - Constructor for class io.reactivex.internal.subscribers.StrictSubscriber
 
Subject<T> - Class in io.reactivex.subjects
Represents an Observer and an Observable at the same time, allowing multicasting events from a single source to multiple child Observers.
Subject() - Constructor for class io.reactivex.subjects.Subject
 
subList(int, int) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
subscribe() - Method in class io.reactivex.Completable
Subscribes to this CompletableConsumable and returns a Disposable which can be used to cancel the subscription.
subscribe(CompletableObserver) - Method in class io.reactivex.Completable
 
subscribe(Action, Consumer<? super Throwable>) - Method in class io.reactivex.Completable
Subscribes to this Completable and calls back either the onError or onComplete functions.
subscribe(Action) - Method in class io.reactivex.Completable
Subscribes to this Completable and calls the given Action when this Completable completes normally.
subscribe(CompletableEmitter) - Method in interface io.reactivex.CompletableOnSubscribe
Called for each CompletableObserver that subscribes.
subscribe(CompletableObserver) - Method in interface io.reactivex.CompletableSource
Subscribes the given CompletableObserver to this CompletableSource instance.
subscribe() - Method in class io.reactivex.Flowable
Subscribes to a Publisher and ignores onNext and onComplete emissions.
subscribe(Consumer<? super T>) - Method in class io.reactivex.Flowable
Subscribes to a Publisher and provides a callback to handle the items it emits.
subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Flowable
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error notification it issues.
subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.Flowable
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error or completion notification it issues.
subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action, Consumer<? super Subscription>) - Method in class io.reactivex.Flowable
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error or completion notification it issues.
subscribe(Subscriber<? super T>) - Method in class io.reactivex.Flowable
 
subscribe(FlowableSubscriber<? super T>) - Method in class io.reactivex.Flowable
Establish a connection between this Flowable and the given FlowableSubscriber and start streaming events based on the demand of the FlowableSubscriber.
subscribe(FlowableEmitter<T>) - Method in interface io.reactivex.FlowableOnSubscribe
Called for each Subscriber that subscribes.
subscribe(Publisher<? extends T>, Subscriber<? super T>) - Static method in class io.reactivex.internal.operators.flowable.FlowableBlockingSubscribe
Subscribes to the source and calls the Subscriber methods on the current thread.
subscribe(Publisher<? extends T>) - Static method in class io.reactivex.internal.operators.flowable.FlowableBlockingSubscribe
Runs the source observable to a terminal event, ignoring any values and rethrowing any exception.
subscribe(Publisher<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Action) - Static method in class io.reactivex.internal.operators.flowable.FlowableBlockingSubscribe
Subscribes to the source and calls the given actions on the current thread.
subscribe(Publisher<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Action, int) - Static method in class io.reactivex.internal.operators.flowable.FlowableBlockingSubscribe
Subscribes to the source and calls the given actions on the current thread.
subscribe(Subscriber<? super R>, Function<? super T, ? extends Publisher<? extends R>>, int, ErrorMode) - Static method in class io.reactivex.internal.operators.flowable.FlowableConcatMap
 
subscribe(Subscriber<? super U>, Function<? super T, ? extends Publisher<? extends U>>, boolean, int, int) - Static method in class io.reactivex.internal.operators.flowable.FlowableFlatMap
 
subscribe(Subscriber<? super T>, Iterator<? extends T>) - Static method in class io.reactivex.internal.operators.flowable.FlowableFromIterable
 
subscribe(ObservableSource<? extends T>, Observer<? super T>) - Static method in class io.reactivex.internal.operators.observable.ObservableBlockingSubscribe
Subscribes to the source and calls the Observer methods on the current thread.
subscribe(ObservableSource<? extends T>) - Static method in class io.reactivex.internal.operators.observable.ObservableBlockingSubscribe
Runs the source observable to a terminal event, ignoring any values and rethrowing any exception.
subscribe(ObservableSource<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Action) - Static method in class io.reactivex.internal.operators.observable.ObservableBlockingSubscribe
Subscribes to the source and calls the given actions on the current thread.
subscribe(Subscriber<? super C>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelCollect
 
subscribe(Subscriber<? super R>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelConcatMap
 
subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelDoOnNextTry
 
subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelFilter
 
subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelFilterTry
 
subscribe(Subscriber<? super R>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelFlatMap
 
subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelFromArray
 
subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelFromPublisher
 
subscribe(Subscriber<? super R>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelMap
 
subscribe(Subscriber<? super R>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelMapTry
 
subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelPeek
 
subscribe(Subscriber<? super R>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelReduce
 
subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.internal.operators.parallel.ParallelRunOn
 
subscribe() - Method in class io.reactivex.Maybe
Subscribes to a Maybe and ignores onSuccess and onComplete emissions.
subscribe(Consumer<? super T>) - Method in class io.reactivex.Maybe
Subscribes to a Maybe and provides a callback to handle the items it emits.
subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Maybe
Subscribes to a Maybe and provides callbacks to handle the items it emits and any error notification it issues.
subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.Maybe
Subscribes to a Maybe and provides callbacks to handle the items it emits and any error or completion notification it issues.
subscribe(MaybeObserver<? super T>) - Method in class io.reactivex.Maybe
 
subscribe(MaybeEmitter<T>) - Method in interface io.reactivex.MaybeOnSubscribe
Called for each MaybeObserver that subscribes.
subscribe(MaybeObserver<? super T>) - Method in interface io.reactivex.MaybeSource
Subscribes the given MaybeObserver to this MaybeSource instance.
subscribe() - Method in class io.reactivex.Observable
Subscribes to an ObservableSource and ignores onNext and onComplete emissions.
subscribe(Consumer<? super T>) - Method in class io.reactivex.Observable
Subscribes to an ObservableSource and provides a callback to handle the items it emits.
subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Observable
Subscribes to an ObservableSource and provides callbacks to handle the items it emits and any error notification it issues.
subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.Observable
Subscribes to an ObservableSource and provides callbacks to handle the items it emits and any error or completion notification it issues.
subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action, Consumer<? super Disposable>) - Method in class io.reactivex.Observable
Subscribes to an ObservableSource and provides callbacks to handle the items it emits and any error or completion notification it issues.
subscribe(Observer<? super T>) - Method in class io.reactivex.Observable
 
subscribe(ObservableEmitter<T>) - Method in interface io.reactivex.ObservableOnSubscribe
Called for each Observer that subscribes.
subscribe(Observer<? super T>) - Method in interface io.reactivex.ObservableSource
Subscribes the given Observer to this ObservableSource instance.
subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.parallel.ParallelFlowable
Subscribes an array of Subscribers to this ParallelFlowable and triggers the execution chain for all 'rails'.
subscribe() - Method in class io.reactivex.Single
Subscribes to a Single but ignore its emission or notification.
subscribe(BiConsumer<? super T, ? super Throwable>) - Method in class io.reactivex.Single
Subscribes to a Single and provides a composite callback to handle the item it emits or any error notification it issues.
subscribe(Consumer<? super T>) - Method in class io.reactivex.Single
Subscribes to a Single and provides a callback to handle the item it emits.
subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Single
Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it issues.
subscribe(SingleObserver<? super T>) - Method in class io.reactivex.Single
 
subscribe(SingleEmitter<T>) - Method in interface io.reactivex.SingleOnSubscribe
Called for each SingleObserver that subscribes.
subscribe(SingleObserver<? super T>) - Method in interface io.reactivex.SingleSource
Subscribes the given SingleObserver to this SingleSource instance.
subscribeActual(CompletableObserver) - Method in class io.reactivex.Completable
Implement this method to handle the incoming CompletableObservers and perform the business logic in your operator.
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.Flowable
Operator implementations (both source and intermediate) should implement this method that performs the necessary business logic and handles the incoming Subscribers.
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableAmb
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableCache
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableConcat
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableConcatArray
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableConcatIterable
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableCreate
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableDefer
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableDelay
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableDetach
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableDisposeOn
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableDoFinally
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableDoOnEvent
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableEmpty
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableError
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableErrorSupplier
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableFromAction
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableFromCallable
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableFromObservable
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableFromPublisher
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableFromRunnable
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableFromSingle
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableFromUnsafeSource
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableHide
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableLift
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableMerge
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableMergeArray
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableMergeDelayErrorArray
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableMergeDelayErrorIterable
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableMergeIterable
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableNever
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableObserveOn
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableOnErrorComplete
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletablePeek
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableResumeNext
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableSubscribeOn
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableTimeout
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableTimer
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.completable.CompletableToFlowable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.completable.CompletableToObservable
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.completable.CompletableToSingle
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.completable.CompletableUsing
 
subscribeActual(Subscriber<? super Boolean>) - Method in class io.reactivex.internal.operators.flowable.FlowableAll
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.flowable.FlowableAllSingle
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableAmb
 
subscribeActual(Subscriber<? super Boolean>) - Method in class io.reactivex.internal.operators.flowable.FlowableAny
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.flowable.FlowableAnySingle
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableAutoConnect
 
subscribeActual(Subscriber<? super C>) - Method in class io.reactivex.internal.operators.flowable.FlowableBuffer
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableBufferBoundary
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableBufferBoundarySupplier
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableBufferExactBoundary
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableBufferTimed
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableCache
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableCollect
 
subscribeActual(SingleObserver<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableCollectSingle
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableCombineLatest
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableConcatArray
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableConcatMap
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableConcatMapEager
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableConcatMapEagerPublisher
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableConcatMapPublisher
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableConcatWithCompletable
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableConcatWithMaybe
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableConcatWithSingle
 
subscribeActual(Subscriber<? super Long>) - Method in class io.reactivex.internal.operators.flowable.FlowableCount
 
subscribeActual(SingleObserver<? super Long>) - Method in class io.reactivex.internal.operators.flowable.FlowableCountSingle
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableCreate
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDebounce
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDebounceTimed
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDefer
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDelay
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDelaySubscriptionOther
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDematerialize
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDetach
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDistinct
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDistinctUntilChanged
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDoAfterNext
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDoFinally
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDoOnEach
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableDoOnLifecycle
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableElementAt
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableElementAtMaybe
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableElementAtSingle
 
subscribeActual(Subscriber<? super Object>) - Method in class io.reactivex.internal.operators.flowable.FlowableEmpty
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableError
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableFilter
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableFlatMap
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableFlatMapCompletable
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.flowable.FlowableFlatMapCompletableCompletable
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableFlatMapMaybe
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableFlatMapPublisher
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableFlatMapSingle
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableFlattenIterable
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableFromArray
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableFromCallable
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableFromFuture
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableFromIterable
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableFromObservable
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableFromPublisher
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableGenerate
 
subscribeActual(Subscriber<? super GroupedFlowable<K, V>>) - Method in class io.reactivex.internal.operators.flowable.FlowableGroupBy
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableGroupJoin
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableHide
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableIgnoreElements
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.flowable.FlowableIgnoreElementsCompletable
 
subscribeActual(Subscriber<? super Long>) - Method in class io.reactivex.internal.operators.flowable.FlowableInterval
 
subscribeActual(Subscriber<? super Long>) - Method in class io.reactivex.internal.operators.flowable.FlowableIntervalRange
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableJoin
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableJust
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableLastMaybe
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableLastSingle
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableLift
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableLimit
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableMap
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableMapNotification
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableMapPublisher
 
subscribeActual(Subscriber<? super Notification<T>>) - Method in class io.reactivex.internal.operators.flowable.FlowableMaterialize
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableMergeWithCompletable
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableMergeWithMaybe
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableMergeWithSingle
 
subscribeActual(Subscriber<? super Object>) - Method in class io.reactivex.internal.operators.flowable.FlowableNever
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableObserveOn
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableOnBackpressureBuffer
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableOnBackpressureBufferStrategy
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableOnBackpressureDrop
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableOnBackpressureError
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableOnBackpressureLatest
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableOnErrorNext
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableOnErrorReturn
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowablePublish
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowablePublishMulticast
 
subscribeActual(Subscriber<? super Integer>) - Method in class io.reactivex.internal.operators.flowable.FlowableRange
 
subscribeActual(Subscriber<? super Long>) - Method in class io.reactivex.internal.operators.flowable.FlowableRangeLong
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableReduce
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableReduceMaybe
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableReduceSeedSingle
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableReduceWithSingle
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableRefCount
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableRepeat
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableRepeatUntil
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableRepeatWhen
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableReplay
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableRetryBiPredicate
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableRetryPredicate
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableRetryWhen
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSamplePublisher
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSampleTimed
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableScan
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableScanSeed
 
subscribeActual(Subscriber<? super Boolean>) - Method in class io.reactivex.internal.operators.flowable.FlowableSequenceEqual
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.flowable.FlowableSequenceEqualSingle
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSerialized
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSingle
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSingleMaybe
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSingleSingle
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSkip
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSkipLast
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSkipLastTimed
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSkipUntil
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSkipWhile
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSubscribeOn
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableSwitchIfEmpty
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableSwitchMap
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTake
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTakeLast
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTakeLastOne
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTakeLastTimed
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTakePublisher
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTakeUntil
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTakeUntilPredicate
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTakeWhile
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableThrottleFirstTimed
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableThrottleLatest
 
subscribeActual(Subscriber<? super Timed<T>>) - Method in class io.reactivex.internal.operators.flowable.FlowableTimeInterval
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTimeout
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableTimeoutTimed
 
subscribeActual(Subscriber<? super Long>) - Method in class io.reactivex.internal.operators.flowable.FlowableTimer
 
subscribeActual(Subscriber<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableToList
 
subscribeActual(SingleObserver<? super U>) - Method in class io.reactivex.internal.operators.flowable.FlowableToListSingle
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableUnsubscribeOn
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.flowable.FlowableUsing
 
subscribeActual(Subscriber<? super Flowable<T>>) - Method in class io.reactivex.internal.operators.flowable.FlowableWindow
 
subscribeActual(Subscriber<? super Flowable<T>>) - Method in class io.reactivex.internal.operators.flowable.FlowableWindowBoundary
 
subscribeActual(Subscriber<? super Flowable<T>>) - Method in class io.reactivex.internal.operators.flowable.FlowableWindowBoundarySelector
 
subscribeActual(Subscriber<? super Flowable<T>>) - Method in class io.reactivex.internal.operators.flowable.FlowableWindowBoundarySupplier
 
subscribeActual(Subscriber<? super Flowable<T>>) - Method in class io.reactivex.internal.operators.flowable.FlowableWindowTimed
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableWithLatestFrom
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableWithLatestFromMany
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.flowable.FlowableZip
 
subscribeActual(Subscriber<? super V>) - Method in class io.reactivex.internal.operators.flowable.FlowableZipIterable
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeAmb
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeCache
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeConcatArray
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeConcatArrayDelayError
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeConcatIterable
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.maybe.MaybeContains
 
subscribeActual(SingleObserver<? super Long>) - Method in class io.reactivex.internal.operators.maybe.MaybeCount
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeCreate
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDefer
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDelay
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDelayOtherPublisher
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDelaySubscriptionOtherPublisher
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDelayWithCompletable
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDetach
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDoAfterSuccess
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDoFinally
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeDoOnEvent
 
subscribeActual(MaybeObserver<? super Object>) - Method in class io.reactivex.internal.operators.maybe.MaybeEmpty
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.maybe.MaybeEqualSingle
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeError
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeErrorCallable
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeFilter
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeFilterSingle
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeFlatMapBiSelector
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.maybe.MaybeFlatMapCompletable
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeFlatMapIterableFlowable
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeFlatMapIterableObservable
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeFlatMapNotification
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeFlatMapSingle
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeFlatMapSingleElement
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeFlatten
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeFromAction
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeFromCallable
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeFromCompletable
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeFromFuture
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeFromRunnable
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeFromSingle
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeHide
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeIgnoreElement
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.maybe.MaybeIgnoreElementCompletable
 
subscribeActual(MaybeObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.maybe.MaybeIsEmpty
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.maybe.MaybeIsEmptySingle
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeJust
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeLift
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeMap
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeMergeArray
 
subscribeActual(MaybeObserver<? super Object>) - Method in class io.reactivex.internal.operators.maybe.MaybeNever
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeObserveOn
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeOnErrorComplete
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeOnErrorNext
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeOnErrorReturn
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybePeek
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeSubscribeOn
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeSwitchIfEmpty
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeSwitchIfEmptySingle
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeTakeUntilMaybe
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeTakeUntilPublisher
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeTimeoutMaybe
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeTimeoutPublisher
 
subscribeActual(MaybeObserver<? super Long>) - Method in class io.reactivex.internal.operators.maybe.MaybeTimer
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeToFlowable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeToObservable
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeToSingle
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeUnsafeCreate
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeUnsubscribeOn
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.maybe.MaybeUsing
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeZipArray
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.maybe.MaybeZipIterable
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.mixed.CompletableAndThenObservable
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.mixed.CompletableAndThenPublisher
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.mixed.FlowableConcatMapCompletable
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.mixed.FlowableConcatMapMaybe
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.mixed.FlowableConcatMapSingle
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.mixed.FlowableSwitchMapCompletable
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.mixed.FlowableSwitchMapMaybe
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.mixed.FlowableSwitchMapSingle
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.mixed.MaybeFlatMapObservable
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.mixed.MaybeFlatMapPublisher
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.mixed.ObservableConcatMapCompletable
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.mixed.ObservableConcatMapMaybe
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.mixed.ObservableConcatMapSingle
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.mixed.ObservableSwitchMapCompletable
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.mixed.ObservableSwitchMapMaybe
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.mixed.ObservableSwitchMapSingle
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.mixed.SingleFlatMapObservable
 
subscribeActual(Observer<? super Boolean>) - Method in class io.reactivex.internal.operators.observable.ObservableAll
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.observable.ObservableAllSingle
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableAmb
 
subscribeActual(Observer<? super Boolean>) - Method in class io.reactivex.internal.operators.observable.ObservableAny
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.observable.ObservableAnySingle
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableAutoConnect
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableBuffer
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableBufferBoundary
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableBufferBoundarySupplier
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableBufferExactBoundary
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableBufferTimed
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableCache
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableCollect
 
subscribeActual(SingleObserver<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableCollectSingle
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableCombineLatest
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableConcatMap
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableConcatMapEager
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableConcatWithCompletable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableConcatWithMaybe
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableConcatWithSingle
 
subscribeActual(Observer<? super Long>) - Method in class io.reactivex.internal.operators.observable.ObservableCount
 
subscribeActual(SingleObserver<? super Long>) - Method in class io.reactivex.internal.operators.observable.ObservableCountSingle
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableCreate
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDebounce
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDebounceTimed
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDefer
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDelay
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDelaySubscriptionOther
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDematerialize
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDetach
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDistinct
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDistinctUntilChanged
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDoAfterNext
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDoFinally
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDoOnEach
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableDoOnLifecycle
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableElementAt
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableElementAtMaybe
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableElementAtSingle
 
subscribeActual(Observer<? super Object>) - Method in class io.reactivex.internal.operators.observable.ObservableEmpty
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableError
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableFilter
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableFlatMap
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableFlatMapCompletable
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.observable.ObservableFlatMapCompletableCompletable
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableFlatMapMaybe
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableFlatMapSingle
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableFlattenIterable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableFromArray
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableFromCallable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableFromFuture
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableFromIterable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableFromPublisher
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableFromUnsafeSource
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableGenerate
 
subscribeActual(Observer<? super GroupedObservable<K, V>>) - Method in class io.reactivex.internal.operators.observable.ObservableGroupBy
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableGroupJoin
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableHide
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableIgnoreElements
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.observable.ObservableIgnoreElementsCompletable
 
subscribeActual(Observer<? super Long>) - Method in class io.reactivex.internal.operators.observable.ObservableInterval
 
subscribeActual(Observer<? super Long>) - Method in class io.reactivex.internal.operators.observable.ObservableIntervalRange
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableJoin
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableJust
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableLastMaybe
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableLastSingle
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableLift
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableMap
 
subscribeActual(Observer<? super ObservableSource<? extends R>>) - Method in class io.reactivex.internal.operators.observable.ObservableMapNotification
 
subscribeActual(Observer<? super Notification<T>>) - Method in class io.reactivex.internal.operators.observable.ObservableMaterialize
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableMergeWithCompletable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableMergeWithMaybe
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableMergeWithSingle
 
subscribeActual(Observer<? super Object>) - Method in class io.reactivex.internal.operators.observable.ObservableNever
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableObserveOn
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableOnErrorNext
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableOnErrorReturn
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservablePublish
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservablePublishSelector
 
subscribeActual(Observer<? super Integer>) - Method in class io.reactivex.internal.operators.observable.ObservableRange
 
subscribeActual(Observer<? super Long>) - Method in class io.reactivex.internal.operators.observable.ObservableRangeLong
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableReduceMaybe
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableReduceSeedSingle
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableReduceWithSingle
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableRefCount
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableRepeat
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableRepeatUntil
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableRepeatWhen
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableReplay
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableRetryBiPredicate
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableRetryPredicate
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableRetryWhen
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSampleTimed
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSampleWithObservable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableScan
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableScanSeed
 
subscribeActual(Observer<? super Boolean>) - Method in class io.reactivex.internal.operators.observable.ObservableSequenceEqual
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.observable.ObservableSequenceEqualSingle
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSerialized
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSingleMaybe
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSingleSingle
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSkip
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSkipLast
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSkipLastTimed
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSkipUntil
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSkipWhile
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSubscribeOn
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableSwitchIfEmpty
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableSwitchMap
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTake
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTakeLast
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTakeLastOne
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTakeLastTimed
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTakeUntil
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTakeUntilPredicate
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTakeWhile
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableThrottleFirstTimed
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableThrottleLatest
 
subscribeActual(Observer<? super Timed<T>>) - Method in class io.reactivex.internal.operators.observable.ObservableTimeInterval
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTimeout
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableTimeoutTimed
 
subscribeActual(Observer<? super Long>) - Method in class io.reactivex.internal.operators.observable.ObservableTimer
 
subscribeActual(Observer<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableToList
 
subscribeActual(SingleObserver<? super U>) - Method in class io.reactivex.internal.operators.observable.ObservableToListSingle
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableUnsubscribeOn
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.observable.ObservableUsing
 
subscribeActual(Observer<? super Observable<T>>) - Method in class io.reactivex.internal.operators.observable.ObservableWindow
 
subscribeActual(Observer<? super Observable<T>>) - Method in class io.reactivex.internal.operators.observable.ObservableWindowBoundary
 
subscribeActual(Observer<? super Observable<T>>) - Method in class io.reactivex.internal.operators.observable.ObservableWindowBoundarySelector
 
subscribeActual(Observer<? super Observable<T>>) - Method in class io.reactivex.internal.operators.observable.ObservableWindowBoundarySupplier
 
subscribeActual(Observer<? super Observable<T>>) - Method in class io.reactivex.internal.operators.observable.ObservableWindowTimed
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableWithLatestFrom
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableWithLatestFromMany
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.observable.ObservableZip
 
subscribeActual(Observer<? super V>) - Method in class io.reactivex.internal.operators.observable.ObservableZipIterable
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.parallel.ParallelJoin
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.parallel.ParallelReduceFull
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.parallel.ParallelSortedJoin
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleAmb
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleCache
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.single.SingleContains
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleCreate
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDefer
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDelay
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDelayWithCompletable
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDelayWithObservable
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDelayWithPublisher
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDelayWithSingle
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDetach
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDoAfterSuccess
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDoAfterTerminate
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDoFinally
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDoOnDispose
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDoOnError
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDoOnEvent
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDoOnSubscribe
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleDoOnSuccess
 
subscribeActual(SingleObserver<? super Boolean>) - Method in class io.reactivex.internal.operators.single.SingleEquals
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleError
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.single.SingleFlatMap
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.internal.operators.single.SingleFlatMapCompletable
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.single.SingleFlatMapIterableFlowable
 
subscribeActual(Observer<? super R>) - Method in class io.reactivex.internal.operators.single.SingleFlatMapIterableObservable
 
subscribeActual(MaybeObserver<? super R>) - Method in class io.reactivex.internal.operators.single.SingleFlatMapMaybe
 
subscribeActual(Subscriber<? super R>) - Method in class io.reactivex.internal.operators.single.SingleFlatMapPublisher
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleFromCallable
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleFromPublisher
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleFromUnsafeSource
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleHide
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleJust
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.single.SingleLift
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.single.SingleMap
 
subscribeActual(SingleObserver<? super Object>) - Method in class io.reactivex.internal.operators.single.SingleNever
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleObserveOn
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleOnErrorReturn
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleResumeNext
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleSubscribeOn
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleTakeUntil
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleTimeout
 
subscribeActual(SingleObserver<? super Long>) - Method in class io.reactivex.internal.operators.single.SingleTimer
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.internal.operators.single.SingleToFlowable
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.internal.operators.single.SingleToObservable
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleUnsubscribeOn
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.internal.operators.single.SingleUsing
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.single.SingleZipArray
 
subscribeActual(SingleObserver<? super R>) - Method in class io.reactivex.internal.operators.single.SingleZipIterable
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.Maybe
Implement this method in subclasses to handle the incoming MaybeObservers.
subscribeActual(Observer<? super T>) - Method in class io.reactivex.Observable
Operator implementations (both source and intermediate) should implement this method that performs the necessary business logic and handles the incoming Observers.
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.processors.AsyncProcessor
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.processors.BehaviorProcessor
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.processors.MulticastProcessor
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.processors.PublishProcessor
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.processors.ReplayProcessor
 
subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.processors.UnicastProcessor
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.Single
Implement this method in subclasses to handle the incoming SingleObservers.
subscribeActual(Observer<? super T>) - Method in class io.reactivex.subjects.AsyncSubject
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.subjects.BehaviorSubject
 
subscribeActual(CompletableObserver) - Method in class io.reactivex.subjects.CompletableSubject
 
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.subjects.MaybeSubject
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.subjects.PublishSubject
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.subjects.ReplaySubject
 
subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.subjects.SingleSubject
 
subscribeActual(Observer<? super T>) - Method in class io.reactivex.subjects.UnicastSubject
 
subscribeOn(Scheduler) - Method in class io.reactivex.Completable
Returns a Completable which subscribes the child subscriber on the specified scheduler, making sure the subscription side-effects happen on that specific thread of the scheduler.
subscribeOn(Scheduler) - Method in class io.reactivex.Flowable
Asynchronously subscribes Subscribers to this Publisher on the specified Scheduler.
subscribeOn(Scheduler, boolean) - Method in class io.reactivex.Flowable
Asynchronously subscribes Subscribers to this Publisher on the specified Scheduler optionally reroutes requests from other threads to the same Scheduler thread.
subscribeOn(Scheduler) - Method in class io.reactivex.Maybe
Asynchronously subscribes subscribers to this Maybe on the specified Scheduler.
subscribeOn(Scheduler) - Method in class io.reactivex.Observable
Asynchronously subscribes Observers to this ObservableSource on the specified Scheduler.
subscribeOn(Scheduler) - Method in class io.reactivex.Single
Asynchronously subscribes subscribers to this Single on the specified Scheduler.
SubscriberCompletableObserver<T> - Class in io.reactivex.internal.observers
 
SubscriberCompletableObserver(Subscriber<? super T>) - Constructor for class io.reactivex.internal.observers.SubscriberCompletableObserver
 
subscriberOnComplete(Subscriber<T>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
subscriberOnError(Subscriber<T>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
subscriberOnNext(Subscriber<T>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
SubscriberResourceWrapper<T> - Class in io.reactivex.internal.subscribers
 
SubscriberResourceWrapper(Subscriber<? super T>) - Constructor for class io.reactivex.internal.subscribers.SubscriberResourceWrapper
 
subscribeWith(E) - Method in class io.reactivex.Completable
Subscribes a given CompletableObserver (subclass) to this Completable and returns the given CompletableObserver as is.
subscribeWith(E) - Method in class io.reactivex.Flowable
Subscribes a given Subscriber (subclass) to this Flowable and returns the given Subscriber as is.
subscribeWith(E) - Method in class io.reactivex.Maybe
Subscribes a given MaybeObserver (subclass) to this Maybe and returns the given MaybeObserver as is.
subscribeWith(E) - Method in class io.reactivex.Observable
Subscribes a given Observer (subclass) to this Observable and returns the given Observer as is.
subscribeWith(E) - Method in class io.reactivex.Single
Subscribes a given SingleObserver (subclass) to this Single and returns the given SingleObserver as is.
subscription(Subscription) - Static method in enum io.reactivex.internal.util.NotificationLite
Converts a Subscription into a notification value.
SubscriptionArbiter - Class in io.reactivex.internal.subscriptions
Arbitrates requests and cancellation between Subscriptions.
SubscriptionArbiter() - Constructor for class io.reactivex.internal.subscriptions.SubscriptionArbiter
 
SubscriptionHelper - Enum in io.reactivex.internal.subscriptions
Utility methods to validate Subscriptions in the various onSubscribe calls.
SuppressAnimalSniffer - Annotation Type in io.reactivex.internal.util
Suppress errors by the AnimalSniffer plugin.
switchIfEmpty(Publisher<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by the source Publisher or the items of an alternate Publisher if the source Publisher is empty.
switchIfEmpty(MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Returns a Maybe that emits the items emitted by the source Maybe or the items of an alternate MaybeSource if the current Maybe is empty.
switchIfEmpty(SingleSource<? extends T>) - Method in class io.reactivex.Maybe
Returns a Single that emits the items emitted by the source Maybe or the item of an alternate SingleSource if the current Maybe is empty.
switchIfEmpty(ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by the source ObservableSource or the items of an alternate ObservableSource if the source ObservableSource is empty.
switchMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.Flowable
Returns a new Publisher by applying a function that you supply to each item emitted by the source Publisher that returns a Publisher, and then emitting the items emitted by the most recently emitted of these Publishers.
switchMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.Flowable
Returns a new Publisher by applying a function that you supply to each item emitted by the source Publisher that returns a Publisher, and then emitting the items emitted by the most recently emitted of these Publishers.
switchMap(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Observable
Returns a new ObservableSource by applying a function that you supply to each item emitted by the source ObservableSource that returns an ObservableSource, and then emitting the items emitted by the most recently emitted of these ObservableSources.
switchMap(Function<? super T, ? extends ObservableSource<? extends R>>, int) - Method in class io.reactivex.Observable
Returns a new ObservableSource by applying a function that you supply to each item emitted by the source ObservableSource that returns an ObservableSource, and then emitting the items emitted by the most recently emitted of these ObservableSources.
switchMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Flowable
Maps the upstream values into CompletableSources, subscribes to the newer one while disposing the subscription to the previous CompletableSource, thus keeping at most one active CompletableSource running.
switchMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Observable
Maps the upstream values into CompletableSources, subscribes to the newer one while disposing the subscription to the previous CompletableSource, thus keeping at most one active CompletableSource running.
switchMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Flowable
Maps the upstream values into CompletableSources, subscribes to the newer one while disposing the subscription to the previous CompletableSource, thus keeping at most one active CompletableSource running and delaying any main or inner errors until all of them terminate.
switchMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Observable
Maps the upstream values into CompletableSources, subscribes to the newer one while disposing the subscription to the previous CompletableSource, thus keeping at most one active CompletableSource running and delaying any main or inner errors until all of them terminate.
switchMapDelayError(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.Flowable
Returns a new Publisher by applying a function that you supply to each item emitted by the source Publisher that returns a Publisher, and then emitting the items emitted by the most recently emitted of these Publishers and delays any error until all Publishers terminate.
switchMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.Flowable
Returns a new Publisher by applying a function that you supply to each item emitted by the source Publisher that returns a Publisher, and then emitting the items emitted by the most recently emitted of these Publishers and delays any error until all Publishers terminate.
switchMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.Observable
Returns a new ObservableSource by applying a function that you supply to each item emitted by the source ObservableSource that returns an ObservableSource, and then emitting the items emitted by the most recently emitted of these ObservableSources and delays any error until all ObservableSources terminate.
switchMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, int) - Method in class io.reactivex.Observable
Returns a new ObservableSource by applying a function that you supply to each item emitted by the source ObservableSource that returns an ObservableSource, and then emitting the items emitted by the most recently emitted of these ObservableSources and delays any error until all ObservableSources terminate.
switchMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items into MaybeSources and switches (subscribes) to the newer ones while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if available while failing immediately if this Flowable or any of the active inner MaybeSources fail.
switchMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items into MaybeSources and switches (subscribes) to the newer ones while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if available while failing immediately if this Observable or any of the active inner MaybeSources fail.
switchMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items into MaybeSources and switches (subscribes) to the newer ones while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if available, delaying errors from this Flowable or the inner MaybeSources until all terminate.
switchMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items into MaybeSources and switches (subscribes) to the newer ones while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if available, delaying errors from this Observable or the inner MaybeSources until all terminate.
switchMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items into SingleSources and switches (subscribes) to the newer ones while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one while failing immediately if this Flowable or any of the active inner SingleSources fail.
switchMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Observable
Returns a new ObservableSource by applying a function that you supply to each item emitted by the source ObservableSource that returns a SingleSource, and then emitting the item emitted by the most recently emitted of these SingleSources.
switchMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items into SingleSources and switches (subscribes) to the newer ones while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one, delaying errors from this Flowable or the inner SingleSources until all terminate.
switchMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Observable
Returns a new ObservableSource by applying a function that you supply to each item emitted by the source ObservableSource that returns a SingleSource, and then emitting the item emitted by the most recently emitted of these SingleSources and delays any error until all SingleSources terminate.
switchOnNext(Publisher<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.Flowable
Converts a Publisher that emits Publishers into a Publisher that emits the items emitted by the most recently emitted of those Publishers.
switchOnNext(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Converts a Publisher that emits Publishers into a Publisher that emits the items emitted by the most recently emitted of those Publishers.
switchOnNext(ObservableSource<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.Observable
Converts an ObservableSource that emits ObservableSources into an ObservableSource that emits the items emitted by the most recently emitted of those ObservableSources.
switchOnNext(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Converts an ObservableSource that emits ObservableSources into an ObservableSource that emits the items emitted by the most recently emitted of those ObservableSources.
switchOnNextDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.Flowable
Converts a Publisher that emits Publishers into a Publisher that emits the items emitted by the most recently emitted of those Publishers and delays any exception until all Publishers terminate.
switchOnNextDelayError(Publisher<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.Flowable
Converts a Publisher that emits Publishers into a Publisher that emits the items emitted by the most recently emitted of those Publishers and delays any exception until all Publishers terminate.
switchOnNextDelayError(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.Observable
Converts an ObservableSource that emits ObservableSources into an ObservableSource that emits the items emitted by the most recently emitted of those ObservableSources and delays any exception until all ObservableSources terminate.
switchOnNextDelayError(ObservableSource<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.Observable
Converts an ObservableSource that emits ObservableSources into an ObservableSource that emits the items emitted by the most recently emitted of those ObservableSources and delays any exception until all ObservableSources terminate.
SYNC - Static variable in interface io.reactivex.internal.fuseable.QueueFuseable
Request a synchronous fusion mode and can be returned by QueueFuseable.requestFusion(int) for an accepted mode.

T

tag - Variable in class io.reactivex.observers.BaseTestConsumer
The optional tag associated with this test consumer.
take(long) - Method in class io.reactivex.Flowable
Returns a Flowable that emits only the first count items emitted by the source Publisher.
take(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits those items emitted by source Publisher before a specified time runs out.
take(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits those items emitted by source Publisher before a specified time (on a specified Scheduler) runs out.
take(long) - Method in class io.reactivex.Observable
Returns an Observable that emits only the first count items emitted by the source ObservableSource.
take(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits those items emitted by source ObservableSource before a specified time runs out.
take(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits those items emitted by source ObservableSource before a specified time (on a specified Scheduler) runs out.
takeLast(int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits at most the last count items emitted by the source Publisher.
takeLast(long, long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits at most a specified number of items from the source Publisher that were emitted in a specified window of time before the Publisher completed.
takeLast(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits at most a specified number of items from the source Publisher that were emitted in a specified window of time before the Publisher completed, where the timing information is provided by a given Scheduler.
takeLast(long, long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits at most a specified number of items from the source Publisher that were emitted in a specified window of time before the Publisher completed, where the timing information is provided by a given Scheduler.
takeLast(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified window of time before the Publisher completed.
takeLast(long, TimeUnit, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified window of time before the Publisher completed.
takeLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified window of time before the Publisher completed, where the timing information is provided by a specified Scheduler.
takeLast(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified window of time before the Publisher completed, where the timing information is provided by a specified Scheduler.
takeLast(long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified window of time before the Publisher completed, where the timing information is provided by a specified Scheduler.
takeLast(int) - Method in class io.reactivex.Observable
Returns an Observable that emits at most the last count items emitted by the source ObservableSource.
takeLast(long, long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits at most a specified number of items from the source ObservableSource that were emitted in a specified window of time before the ObservableSource completed.
takeLast(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits at most a specified number of items from the source ObservableSource that were emitted in a specified window of time before the ObservableSource completed, where the timing information is provided by a given Scheduler.
takeLast(long, long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.Observable
Returns an Observable that emits at most a specified number of items from the source ObservableSource that were emitted in a specified window of time before the ObservableSource completed, where the timing information is provided by a given Scheduler.
takeLast(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits the items from the source ObservableSource that were emitted in a specified window of time before the ObservableSource completed.
takeLast(long, TimeUnit, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits the items from the source ObservableSource that were emitted in a specified window of time before the ObservableSource completed.
takeLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits the items from the source ObservableSource that were emitted in a specified window of time before the ObservableSource completed, where the timing information is provided by a specified Scheduler.
takeLast(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits the items from the source ObservableSource that were emitted in a specified window of time before the ObservableSource completed, where the timing information is provided by a specified Scheduler.
takeLast(long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.Observable
Returns an Observable that emits the items from the source ObservableSource that were emitted in a specified window of time before the ObservableSource completed, where the timing information is provided by a specified Scheduler.
takeUntil(Predicate<? super T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items emitted by the source Publisher, checks the specified predicate for each item, and then completes when the condition is satisfied.
takeUntil(Publisher<U>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits the items emitted by the source Publisher until a second Publisher emits an item.
takeUntil(MaybeSource<U>) - Method in class io.reactivex.Maybe
Returns a Maybe that emits the items emitted by the source Maybe until a second MaybeSource emits an item.
takeUntil(Publisher<U>) - Method in class io.reactivex.Maybe
Returns a Maybe that emits the item emitted by the source Maybe until a second Publisher emits an item.
takeUntil(ObservableSource<U>) - Method in class io.reactivex.Observable
Returns an Observable that emits the items emitted by the source Observable until a second ObservableSource emits an item.
takeUntil(Predicate<? super T>) - Method in class io.reactivex.Observable
Returns an Observable that emits items emitted by the source Observable, checks the specified predicate for each item, and then completes when the condition is satisfied.
takeUntil(CompletableSource) - Method in class io.reactivex.Single
Returns a Single that emits the item emitted by the source Single until a Completable terminates.
takeUntil(Publisher<E>) - Method in class io.reactivex.Single
Returns a Single that emits the item emitted by the source Single until a Publisher emits an item.
takeUntil(SingleSource<? extends E>) - Method in class io.reactivex.Single
Returns a Single that emits the item emitted by the source Single until a second Single emits an item.
takeWhile(Predicate<? super T>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items emitted by the source Publisher so long as each item satisfied a specified condition, and then completes as soon as this condition is not satisfied.
takeWhile(Predicate<? super T>) - Method in class io.reactivex.Observable
Returns an Observable that emits items emitted by the source ObservableSource so long as each item satisfied a specified condition, and then completes as soon as this condition is not satisfied.
terminate() - Method in class io.reactivex.internal.util.AtomicThrowable
Atomically terminate the container and return the contents of the last non-terminal Throwable of it.
terminate(AtomicReference<Throwable>) - Static method in class io.reactivex.internal.util.ExceptionHelper
 
TERMINATED - Static variable in class io.reactivex.internal.observers.BlockingObserver
 
TERMINATED - Static variable in class io.reactivex.internal.subscribers.BlockingSubscriber
 
TERMINATED - Static variable in class io.reactivex.internal.util.ExceptionHelper
A singleton instance of a Throwable indicating a terminal state for exceptions, don't leak this.
test() - Method in class io.reactivex.Completable
Creates a TestObserver and subscribes it to this Completable.
test(boolean) - Method in class io.reactivex.Completable
Creates a TestObserver optionally in cancelled state, then subscribes it to this Completable.
test() - Method in class io.reactivex.Flowable
Creates a TestSubscriber that requests Long.MAX_VALUE and subscribes it to this Flowable.
test(long) - Method in class io.reactivex.Flowable
Creates a TestSubscriber with the given initial request amount and subscribes it to this Flowable.
test(long, boolean) - Method in class io.reactivex.Flowable
Creates a TestSubscriber with the given initial request amount, optionally cancels it before the subscription and subscribes it to this Flowable.
test(T1, T2) - Method in interface io.reactivex.functions.BiPredicate
Test the given input values and return a boolean.
test(T) - Method in interface io.reactivex.functions.Predicate
Test the given input value and return a boolean.
test(T) - Method in interface io.reactivex.internal.util.AppendOnlyLinkedArrayList.NonThrowingPredicate
 
test() - Method in class io.reactivex.Maybe
Creates a TestObserver and subscribes it to this Maybe.
test(boolean) - Method in class io.reactivex.Maybe
Creates a TestObserver optionally in cancelled state, then subscribes it to this Maybe.
test() - Method in class io.reactivex.Observable
Creates a TestObserver and subscribes it to this Observable.
test(boolean) - Method in class io.reactivex.Observable
Creates a TestObserver, optionally disposes it and then subscribes it to this Observable.
test() - Method in class io.reactivex.Single
Creates a TestObserver and subscribes it to this Single.
test(boolean) - Method in class io.reactivex.Single
Creates a TestObserver optionally in cancelled state, then subscribes it to this Single.
TestObserver<T> - Class in io.reactivex.observers
An Observer that records events and allows making assertions about them.
TestObserver() - Constructor for class io.reactivex.observers.TestObserver
Constructs a non-forwarding TestObserver.
TestObserver(Observer<? super T>) - Constructor for class io.reactivex.observers.TestObserver
Constructs a forwarding TestObserver.
TestScheduler - Class in io.reactivex.schedulers
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() - Constructor for class io.reactivex.schedulers.TestScheduler
Creates a new TestScheduler with initial virtual time of zero.
TestScheduler(long, TimeUnit) - Constructor for class io.reactivex.schedulers.TestScheduler
Creates a new TestScheduler with the specified initial virtual time.
TestSubscriber<T> - Class in io.reactivex.subscribers
A subscriber that records events and allows making assertions about them.
TestSubscriber() - Constructor for class io.reactivex.subscribers.TestSubscriber
Constructs a non-forwarding TestSubscriber with an initial request value of Long.MAX_VALUE.
TestSubscriber(long) - Constructor for class io.reactivex.subscribers.TestSubscriber
Constructs a non-forwarding TestSubscriber with the specified initial request value.
TestSubscriber(Subscriber<? super T>) - Constructor for class io.reactivex.subscribers.TestSubscriber
Constructs a forwarding TestSubscriber but leaves the requesting to the wrapped subscriber.
TestSubscriber(Subscriber<? super T>, long) - Constructor for class io.reactivex.subscribers.TestSubscriber
Constructs a forwarding TestSubscriber with the specified initial request value.
throttleFirst(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits only the first item emitted by the source Publisher during sequential time windows of a specified duration.
throttleFirst(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits only the first item emitted by the source Publisher during sequential time windows of a specified duration, where the windows are managed by a specified Scheduler.
throttleFirst(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits only the first item emitted by the source ObservableSource during sequential time windows of a specified duration.
throttleFirst(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits only the first item emitted by the source ObservableSource during sequential time windows of a specified duration, where the windows are managed by a specified Scheduler.
throttleLast(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits only the last item emitted by the source Publisher during sequential time windows of a specified duration.
throttleLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits only the last item emitted by the source Publisher during sequential time windows of a specified duration, where the duration is governed by a specified Scheduler.
throttleLast(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits only the last item emitted by the source ObservableSource during sequential time windows of a specified duration.
throttleLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits only the last item emitted by the source ObservableSource during sequential time windows of a specified duration, where the duration is governed by a specified Scheduler.
throttleLatest(long, TimeUnit) - Method in class io.reactivex.Flowable
Throttles items from the upstream Flowable by first emitting the next item from upstream, then periodically emitting the latest item (if any) when the specified timeout elapses between them.
throttleLatest(long, TimeUnit, boolean) - Method in class io.reactivex.Flowable
Throttles items from the upstream Flowable by first emitting the next item from upstream, then periodically emitting the latest item (if any) when the specified timeout elapses between them.
throttleLatest(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Throttles items from the upstream Flowable by first emitting the next item from upstream, then periodically emitting the latest item (if any) when the specified timeout elapses between them.
throttleLatest(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Flowable
Throttles items from the upstream Flowable by first emitting the next item from upstream, then periodically emitting the latest item (if any) when the specified timeout elapses between them.
throttleLatest(long, TimeUnit) - Method in class io.reactivex.Observable
Throttles items from the upstream Observable by first emitting the next item from upstream, then periodically emitting the latest item (if any) when the specified timeout elapses between them.
throttleLatest(long, TimeUnit, boolean) - Method in class io.reactivex.Observable
Throttles items from the upstream Observable by first emitting the next item from upstream, then periodically emitting the latest item (if any) when the specified timeout elapses between them.
throttleLatest(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Throttles items from the upstream Observable by first emitting the next item from upstream, then periodically emitting the latest item (if any) when the specified timeout elapses between them.
throttleLatest(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.Observable
Throttles items from the upstream Observable by first emitting the next item from upstream, then periodically emitting the latest item (if any) when the specified timeout elapses between them.
throttleWithTimeout(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the source Publisher that are followed by newer items before a timeout value expires.
throttleWithTimeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the source Publisher that are followed by newer items before a timeout value expires on a specified Scheduler.
throttleWithTimeout(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, except that it drops items emitted by the source ObservableSource that are followed by newer items before a timeout value expires.
throttleWithTimeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, except that it drops items emitted by the source ObservableSource that are followed by newer items before a timeout value expires on a specified Scheduler.
throwIfFatal(Throwable) - Static method in class io.reactivex.exceptions.Exceptions
Throws a particular Throwable only if it belongs to a set of "fatal" error varieties.
throwIfThrowable(Throwable) - Static method in class io.reactivex.internal.util.ExceptionHelper
Workaround for Java 6 not supporting throwing a final Throwable from a catch block.
time() - Method in class io.reactivex.schedulers.Timed
Returns the time value.
time(TimeUnit) - Method in class io.reactivex.schedulers.Timed
Returns the contained time value in the time unit specified.
Timed<T> - Class in io.reactivex.schedulers
Holds onto a value along with time information.
Timed(T, long, TimeUnit) - Constructor for class io.reactivex.schedulers.Timed
Constructs a Timed instance with the given value and time information.
timeInterval() - Method in class io.reactivex.Flowable
Returns a Flowable that emits records of the time interval between consecutive items emitted by the source Publisher.
timeInterval(Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits records of the time interval between consecutive items emitted by the source Publisher, where this interval is computed on a specified Scheduler.
timeInterval(TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits records of the time interval between consecutive items emitted by the source Publisher.
timeInterval(TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits records of the time interval between consecutive items emitted by the source Publisher, where this interval is computed on a specified Scheduler.
timeInterval() - Method in class io.reactivex.Observable
Returns an Observable that emits records of the time interval between consecutive items emitted by the source ObservableSource.
timeInterval(Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits records of the time interval between consecutive items emitted by the source ObservableSource, where this interval is computed on a specified Scheduler.
timeInterval(TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits records of the time interval between consecutive items emitted by the source ObservableSource.
timeInterval(TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits records of the time interval between consecutive items emitted by the source ObservableSource, where this interval is computed on a specified Scheduler.
timeout(long, TimeUnit) - Method in class io.reactivex.Completable
Returns a Completable that runs this Completable and emits a TimeoutException in case this Completable doesn't complete within the given time.
timeout(long, TimeUnit, CompletableSource) - Method in class io.reactivex.Completable
Returns a Completable that runs this Completable and switches to the other Completable in case this Completable doesn't complete within the given time.
timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.Completable
Returns a Completable that runs this Completable and emits a TimeoutException in case this Completable doesn't complete within the given time while "waiting" on the specified Scheduler.
timeout(long, TimeUnit, Scheduler, CompletableSource) - Method in class io.reactivex.Completable
Returns a Completable that runs this Completable and switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.
timeout(Function<? super T, ? extends Publisher<V>>) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, but notifies Subscribers of a TimeoutException if an item emitted by the source Publisher doesn't arrive within a window of time after the emission of the previous item, where that period of time is measured by a Publisher that is a function of the previous item.
timeout(Function<? super T, ? extends Publisher<V>>, Flowable<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, but that switches to a fallback Publisher if an item emitted by the source Publisher doesn't arrive within a window of time after the emission of the previous item, where that period of time is measured by a Publisher that is a function of the previous item.
timeout(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher but applies a timeout policy for each emitted item.
timeout(long, TimeUnit, Publisher<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher but applies a timeout policy for each emitted item.
timeout(long, TimeUnit, Scheduler, Publisher<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher but applies a timeout policy for each emitted item using a specified Scheduler.
timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher but applies a timeout policy for each emitted item, where this policy is governed by a specified Scheduler.
timeout(Publisher<U>, Function<? super T, ? extends Publisher<V>>) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, but notifies Subscribers of a TimeoutException if either the first item emitted by the source Publisher or any subsequent item doesn't arrive within time windows defined by other Publishers.
timeout(Publisher<U>, Function<? super T, ? extends Publisher<V>>, Publisher<? extends T>) - Method in class io.reactivex.Flowable
Returns a Flowable that mirrors the source Publisher, but switches to a fallback Publisher if either the first item emitted by the source Publisher or any subsequent item doesn't arrive within time windows defined by other Publishers.
timeout(long, TimeUnit) - Method in class io.reactivex.Maybe
Returns a Maybe that mirrors the source Maybe but applies a timeout policy for each emitted item.
timeout(long, TimeUnit, MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Returns a Maybe that mirrors the source Maybe but applies a timeout policy for each emitted item.
timeout(long, TimeUnit, Scheduler, MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Returns a Maybe that mirrors the source Maybe but applies a timeout policy for each emitted item using a specified Scheduler.
timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.Maybe
Returns a Maybe that mirrors the source Maybe but applies a timeout policy for each emitted item, where this policy is governed on a specified Scheduler.
timeout(MaybeSource<U>) - Method in class io.reactivex.Maybe
If the current Maybe didn't signal an event before the timeoutIndicator MaybeSource signals, a TimeoutException is signaled instead.
timeout(MaybeSource<U>, MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
If the current Maybe didn't signal an event before the timeoutIndicator MaybeSource signals, the current Maybe is cancelled and the fallback MaybeSource subscribed to as a continuation.
timeout(Publisher<U>) - Method in class io.reactivex.Maybe
If the current Maybe source didn't signal an event before the timeoutIndicator Publisher signals, a TimeoutException is signaled instead.
timeout(Publisher<U>, MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
If the current Maybe didn't signal an event before the timeoutIndicator Publisher signals, the current Maybe is cancelled and the fallback MaybeSource subscribed to as a continuation.
timeout(Function<? super T, ? extends ObservableSource<V>>) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, but notifies observers of a TimeoutException if an item emitted by the source ObservableSource doesn't arrive within a window of time after the emission of the previous item, where that period of time is measured by an ObservableSource that is a function of the previous item.
timeout(Function<? super T, ? extends ObservableSource<V>>, ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, but that switches to a fallback ObservableSource if an item emitted by the source ObservableSource doesn't arrive within a window of time after the emission of the previous item, where that period of time is measured by an ObservableSource that is a function of the previous item.
timeout(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource but applies a timeout policy for each emitted item.
timeout(long, TimeUnit, ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource but applies a timeout policy for each emitted item.
timeout(long, TimeUnit, Scheduler, ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource but applies a timeout policy for each emitted item using a specified Scheduler.
timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource but applies a timeout policy for each emitted item, where this policy is governed on a specified Scheduler.
timeout(ObservableSource<U>, Function<? super T, ? extends ObservableSource<V>>) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, but notifies observers of a TimeoutException if either the first item emitted by the source ObservableSource or any subsequent item doesn't arrive within time windows defined by other ObservableSources.
timeout(ObservableSource<U>, Function<? super T, ? extends ObservableSource<V>>, ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Returns an Observable that mirrors the source ObservableSource, but switches to a fallback ObservableSource if either the first item emitted by the source ObservableSource or any subsequent item doesn't arrive within time windows defined by other ObservableSources.
timeout - Variable in class io.reactivex.observers.BaseTestConsumer
Indicates that one of the awaitX method has timed out.
timeout(long, TimeUnit) - Method in class io.reactivex.Single
Signals a TimeoutException if the current Single doesn't signal a success value within the specified timeout window.
timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.Single
Signals a TimeoutException if the current Single doesn't signal a success value within the specified timeout window.
timeout(long, TimeUnit, Scheduler, SingleSource<? extends T>) - Method in class io.reactivex.Single
Runs the current Single and if it doesn't signal within the specified timeout window, it is cancelled and the other SingleSource subscribed to.
timeout(long, TimeUnit, SingleSource<? extends T>) - Method in class io.reactivex.Single
Runs the current Single and if it doesn't signal within the specified timeout window, it is cancelled and the other SingleSource subscribed to.
timer(long, TimeUnit) - Static method in class io.reactivex.Completable
Returns a Completable instance that fires its onComplete event after the given delay elapsed.
timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Completable
Returns a Completable instance that fires its onComplete event after the given delay elapsed by using the supplied scheduler.
timer(long, TimeUnit) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits 0L after a specified delay, and then completes.
timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits 0L after a specified delay, on a specified Scheduler, and then completes.
timer(long, TimeUnit) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits 0L after a specified delay.
timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits 0L after a specified delay on a specified Scheduler.
timer(long, TimeUnit) - Static method in class io.reactivex.Observable
Returns an Observable that emits 0L after a specified delay, and then completes.
timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Observable
Returns an Observable that emits 0L after a specified delay, on a specified Scheduler, and then completes.
timer(long, TimeUnit) - Static method in class io.reactivex.Single
Signals success with 0L value after the given delay for each SingleObserver.
timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Single
Signals success with 0L value after the given delay for each SingleObserver.
timestamp() - Method in class io.reactivex.Flowable
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in a Timed object.
timestamp(Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in a Timed object whose timestamps are provided by a specified Scheduler.
timestamp(TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in a Timed object.
timestamp(TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in a Timed object whose timestamps are provided by a specified Scheduler.
timestamp() - Method in class io.reactivex.Observable
Returns an Observable that emits each item emitted by the source ObservableSource, wrapped in a Timed object.
timestamp(Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits each item emitted by the source ObservableSource, wrapped in a Timed object whose timestamps are provided by a specified Scheduler.
timestamp(TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits each item emitted by the source ObservableSource, wrapped in a Timed object.
timestamp(TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits each item emitted by the source ObservableSource, wrapped in a Timed object whose timestamps are provided by a specified Scheduler.
timestampWith(TimeUnit, Scheduler) - Static method in class io.reactivex.internal.functions.Functions
 
to(Function<? super Completable, U>) - Method in class io.reactivex.Completable
Allows fluent conversion to another type via a function callback.
to(Function<? super Flowable<T>, R>) - Method in class io.reactivex.Flowable
Calls the specified converter function during assembly time and returns its resulting value.
to(Function<? super Maybe<T>, R>) - Method in class io.reactivex.Maybe
Calls the specified converter function with the current Maybe instance during assembly time and returns its result.
to(Function<? super Observable<T>, R>) - Method in class io.reactivex.Observable
Calls the specified converter function during assembly time and returns its resulting value.
to(Function<? super ParallelFlowable<T>, U>) - Method in class io.reactivex.parallel.ParallelFlowable
Perform a fluent transformation to a value via a converter function which receives this ParallelFlowable.
to(Function<? super Single<T>, R>) - Method in class io.reactivex.Single
Calls the specified converter function with the current Single instance during assembly time and returns its result.
toArray() - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
toArray(E[]) - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
toCompletable() - Method in class io.reactivex.Single
Deprecated.
see Single.ignoreElement() instead, will be removed in 3.0
toFlowable() - Method in class io.reactivex.Completable
Returns a Flowable which when subscribed to subscribes to this Completable and relays the terminal events to the subscriber.
toFlowable() - Static method in class io.reactivex.internal.operators.single.SingleInternalHelper
 
toFlowable() - Method in class io.reactivex.Maybe
Converts this Maybe into a backpressure-aware Flowable instance composing cancellation through.
toFlowable(BackpressureStrategy) - Method in class io.reactivex.Observable
Converts the current Observable into a Flowable by applying the specified backpressure strategy.
toFlowable() - Method in class io.reactivex.Single
Converts this Single into a Flowable.
toFunction(BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.internal.functions.Functions
 
toFunction(Function3<T1, T2, T3, R>) - Static method in class io.reactivex.internal.functions.Functions
 
toFunction(Function4<T1, T2, T3, T4, R>) - Static method in class io.reactivex.internal.functions.Functions
 
toFunction(Function5<T1, T2, T3, T4, T5, R>) - Static method in class io.reactivex.internal.functions.Functions
 
toFunction(Function6<T1, T2, T3, T4, T5, T6, R>) - Static method in class io.reactivex.internal.functions.Functions
 
toFunction(Function7<T1, T2, T3, T4, T5, T6, T7, R>) - Static method in class io.reactivex.internal.functions.Functions
 
toFunction(Function8<T1, T2, T3, T4, T5, T6, T7, T8, R>) - Static method in class io.reactivex.internal.functions.Functions
 
toFunction(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, R>) - Static method in class io.reactivex.internal.functions.Functions
 
toFuture() - Method in class io.reactivex.Flowable
Returns a Future representing the single value emitted by this Flowable.
toFuture() - Method in class io.reactivex.Observable
Returns a Future representing the single value emitted by this Observable.
toFuture() - Method in class io.reactivex.Single
Returns a Future representing the single value emitted by this Single.
toList() - Method in class io.reactivex.Flowable
Returns a Single that emits a single item, a list composed of all the items emitted by the finite upstream source Publisher.
toList(int) - Method in class io.reactivex.Flowable
Returns a Single that emits a single item, a list composed of all the items emitted by the finite source Publisher.
toList(Callable<U>) - Method in class io.reactivex.Flowable
Returns a Single that emits a single item, a list composed of all the items emitted by the finite source Publisher.
toList() - Method in class io.reactivex.Observable
Returns a Single that emits a single item, a list composed of all the items emitted by the finite source ObservableSource.
toList(int) - Method in class io.reactivex.Observable
Returns a Single that emits a single item, a list composed of all the items emitted by the finite source ObservableSource.
toList(Callable<U>) - Method in class io.reactivex.Observable
Returns a Single that emits a single item, a list composed of all the items emitted by the finite source ObservableSource.
toMap(Function<? super T, ? extends K>) - Method in class io.reactivex.Flowable
Returns a Single that emits a single HashMap containing all items emitted by the finite source Publisher, mapped by the keys returned by a specified keySelector function.
toMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.Flowable
Returns a Single that emits a single HashMap containing values corresponding to items emitted by the finite source Publisher, mapped by the keys returned by a specified keySelector function.
toMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Callable<? extends Map<K, V>>) - Method in class io.reactivex.Flowable
Returns a Single that emits a single Map, returned by a specified mapFactory function, that contains keys and values extracted from the items emitted by the finite source Publisher.
toMap(Function<? super T, ? extends K>) - Method in class io.reactivex.Observable
Returns a Single that emits a single HashMap containing all items emitted by the finite source ObservableSource, mapped by the keys returned by a specified keySelector function.
toMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.Observable
Returns a Single that emits a single HashMap containing values corresponding to items emitted by the finite source ObservableSource, mapped by the keys returned by a specified keySelector function.
toMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Callable<? extends Map<K, V>>) - Method in class io.reactivex.Observable
Returns a Single that emits a single Map, returned by a specified mapFactory function, that contains keys and values extracted from the items emitted by the finite source ObservableSource.
toMapKeySelector(Function<? super T, ? extends K>) - Static method in class io.reactivex.internal.functions.Functions
 
toMapKeyValueSelector(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class io.reactivex.internal.functions.Functions
 
toMaybe() - Method in class io.reactivex.Completable
Converts this Completable into a Maybe.
toMaybe() - Method in class io.reactivex.Single
Converts this Single into a Maybe.
toMultimap(Function<? super T, ? extends K>) - Method in class io.reactivex.Flowable
Returns a Single that emits a single HashMap that contains an ArrayList of items emitted by the finite source Publisher keyed by a specified keySelector function.
toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.Flowable
Returns a Single that emits a single HashMap that contains an ArrayList of values extracted by a specified valueSelector function from items emitted by the finite source Publisher, keyed by a specified keySelector function.
toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Callable<? extends Map<K, Collection<V>>>, Function<? super K, ? extends Collection<? super V>>) - Method in class io.reactivex.Flowable
Returns a Single that emits a single Map, returned by a specified mapFactory function, that contains a custom collection of values, extracted by a specified valueSelector function from items emitted by the finite source Publisher, and keyed by the keySelector function.
toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Callable<Map<K, Collection<V>>>) - Method in class io.reactivex.Flowable
Returns a Single that emits a single Map, returned by a specified mapFactory function, that contains an ArrayList of values, extracted by a specified valueSelector function from items emitted by the finite source Publisher and keyed by the keySelector function.
toMultimap(Function<? super T, ? extends K>) - Method in class io.reactivex.Observable
Returns a Single that emits a single HashMap that contains an ArrayList of items emitted by the finite source ObservableSource keyed by a specified keySelector function.
toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.Observable
Returns a Single that emits a single HashMap that contains an ArrayList of values extracted by a specified valueSelector function from items emitted by the finite source ObservableSource, keyed by a specified keySelector function.
toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Callable<? extends Map<K, Collection<V>>>, Function<? super K, ? extends Collection<? super V>>) - Method in class io.reactivex.Observable
Returns a Single that emits a single Map, returned by a specified mapFactory function, that contains a custom collection of values, extracted by a specified valueSelector function from items emitted by the source ObservableSource, and keyed by the keySelector function.
toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Callable<Map<K, Collection<V>>>) - Method in class io.reactivex.Observable
Returns a Single that emits a single Map, returned by a specified mapFactory function, that contains an ArrayList of values, extracted by a specified valueSelector function from items emitted by the finite source ObservableSource and keyed by the keySelector function.
toMultimapKeyValueSelector(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Function<? super K, ? extends Collection<? super V>>) - Static method in class io.reactivex.internal.functions.Functions
 
toObservable() - Method in class io.reactivex.Completable
Returns an Observable which when subscribed to subscribes to this Completable and relays the terminal events to the subscriber.
toObservable() - Method in class io.reactivex.Flowable
Converts the current Flowable into a non-backpressured Observable.
toObservable() - Static method in class io.reactivex.internal.operators.single.SingleInternalHelper
 
toObservable() - Method in class io.reactivex.Maybe
Converts this Maybe into an Observable instance composing cancellation through.
toObservable() - Method in class io.reactivex.Single
Converts this Single into an Observable.
toSerialized() - Method in class io.reactivex.processors.FlowableProcessor
Wraps this FlowableProcessor and serializes the calls to the onSubscribe, onNext, onError and onComplete methods, making them thread-safe.
toSerialized() - Method in class io.reactivex.subjects.Subject
Wraps this Subject and serializes the calls to the onSubscribe, onNext, onError and onComplete methods, making them thread-safe.
toSingle(Callable<? extends T>) - Method in class io.reactivex.Completable
Converts this Completable into a Single which when this Completable completes normally, calls the given supplier and emits its returned value through onSuccess.
toSingle(T) - Method in class io.reactivex.Maybe
Converts this Maybe into a Single instance composing cancellation through and turning an empty Maybe into a Single that emits the given value through onSuccess.
toSingle() - Method in class io.reactivex.Maybe
Converts this Maybe into a Single instance composing cancellation through and turning an empty Maybe into a signal of NoSuchElementException.
toSingleDefault(T) - Method in class io.reactivex.Completable
Converts this Completable into a Single which when this Completable completes normally, emits the given value through onSuccess.
toSortedList() - Method in class io.reactivex.Flowable
Returns a Single that emits a list that contains the items emitted by the finite source Publisher, in a sorted order.
toSortedList(Comparator<? super T>) - Method in class io.reactivex.Flowable
Returns a Single that emits a list that contains the items emitted by the finite source Publisher, in a sorted order based on a specified comparison function.
toSortedList(Comparator<? super T>, int) - Method in class io.reactivex.Flowable
Returns a Single that emits a list that contains the items emitted by the finite source Publisher, in a sorted order based on a specified comparison function.
toSortedList(int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits a list that contains the items emitted by the finite source Publisher, in a sorted order.
toSortedList() - Method in class io.reactivex.Observable
Returns a Single that emits a list that contains the items emitted by the finite source ObservableSource, in a sorted order.
toSortedList(Comparator<? super T>) - Method in class io.reactivex.Observable
Returns a Single that emits a list that contains the items emitted by the finite source ObservableSource, in a sorted order based on a specified comparison function.
toSortedList(Comparator<? super T>, int) - Method in class io.reactivex.Observable
Returns a Single that emits a list that contains the items emitted by the finite source ObservableSource, in a sorted order based on a specified comparison function.
toSortedList(int) - Method in class io.reactivex.Observable
Returns a Single that emits a list that contains the items emitted by the finite source ObservableSource, in a sorted order.
toSortedList(Comparator<? super T>) - Method in class io.reactivex.parallel.ParallelFlowable
Sorts the 'rails' according to the comparator and returns a full sorted list as a Publisher.
toSortedList(Comparator<? super T>, int) - Method in class io.reactivex.parallel.ParallelFlowable
Sorts the 'rails' according to the comparator and returns a full sorted list as a Publisher.
toString() - Method in class io.reactivex.internal.schedulers.RxThreadFactory
 
toString() - Method in class io.reactivex.internal.subscriptions.BooleanSubscription
 
toString() - Method in enum io.reactivex.internal.subscriptions.EmptySubscription
 
toString() - Method in class io.reactivex.internal.util.LinkedArrayList
 
toString() - Method in enum io.reactivex.internal.util.NotificationLite
 
toString() - Method in class io.reactivex.internal.util.VolatileSizeArrayList
 
toString() - Method in class io.reactivex.Notification
 
toString() - Method in class io.reactivex.schedulers.Timed
 
TRAMPOLINE - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
The operator/class runs on RxJava's trampoline scheduler or takes timing information from it.
trampoline() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, shared Scheduler instance whose Scheduler.Worker instances queue work and execute them in a FIFO manner on one of the participating threads.
TrampolineScheduler - Class in io.reactivex.internal.schedulers
Schedules work on the current thread but does not execute immediately.
transitiveBoundaryFusion(int) - Method in class io.reactivex.internal.observers.BasicFuseableObserver
Calls the upstream's QueueDisposable.requestFusion with the mode and saves the established mode in BasicFuseableObserver.sourceMode if that mode doesn't have the QueueFuseable.BOUNDARY flag set.
transitiveBoundaryFusion(int) - Method in class io.reactivex.internal.subscribers.BasicFuseableConditionalSubscriber
Calls the upstream's QueueSubscription.requestFusion with the mode and saves the established mode in BasicFuseableConditionalSubscriber.sourceMode if that mode doesn't have the QueueFuseable.BOUNDARY flag set.
transitiveBoundaryFusion(int) - Method in class io.reactivex.internal.subscribers.BasicFuseableSubscriber
Calls the upstream's QueueSubscription.requestFusion with the mode and saves the established mode in BasicFuseableSubscriber.sourceMode if that mode doesn't have the QueueFuseable.BOUNDARY flag set.
triggerActions() - Method in class io.reactivex.schedulers.TestScheduler
Triggers any actions that have not yet been triggered and that are scheduled to be triggered at or before this Scheduler's present time.
tryCancel() - Method in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
Atomically sets a cancelled state and returns true if the current thread did it successfully.
tryDispose() - Method in class io.reactivex.internal.observers.DeferredScalarDisposable
Try disposing this Disposable and return true if the current thread succeeded.
tryOnError(Throwable) - Method in interface io.reactivex.CompletableEmitter
Attempts to emit the specified Throwable error if the downstream hasn't cancelled the sequence or is otherwise terminated, returning false if the emission is not allowed to happen due to lifecycle restrictions.
tryOnError(Throwable) - Method in interface io.reactivex.FlowableEmitter
Attempts to emit the specified Throwable error if the downstream hasn't cancelled the sequence or is otherwise terminated, returning false if the emission is not allowed to happen due to lifecycle restrictions.
tryOnError(Throwable) - Method in interface io.reactivex.MaybeEmitter
Attempts to emit the specified Throwable error if the downstream hasn't cancelled the sequence or is otherwise terminated, returning false if the emission is not allowed to happen due to lifecycle restrictions.
tryOnError(Throwable) - Method in interface io.reactivex.ObservableEmitter
Attempts to emit the specified Throwable error if the downstream hasn't cancelled the sequence or is otherwise terminated, returning false if the emission is not allowed to happen due to lifecycle restrictions.
tryOnError(Throwable) - Method in interface io.reactivex.SingleEmitter
Attempts to emit the specified Throwable error if the downstream hasn't cancelled the sequence or is otherwise terminated, returning false if the emission is not allowed to happen due to lifecycle restrictions.
tryOnNext(T) - Method in interface io.reactivex.internal.fuseable.ConditionalSubscriber
Conditionally takes the value.
tryScalarXMapSubscribe(Publisher<T>, Subscriber<? super R>, Function<? super T, ? extends Publisher<? extends R>>) - Static method in class io.reactivex.internal.operators.flowable.FlowableScalarXMap
Tries to subscribe to a possibly Callable source's mapped Publisher.
tryScalarXMapSubscribe(ObservableSource<T>, Observer<? super R>, Function<? super T, ? extends ObservableSource<? extends R>>) - Static method in class io.reactivex.internal.operators.observable.ObservableScalarXMap
Tries to subscribe to a possibly Callable source's mapped ObservableSource.
trySet(AtomicReference<Disposable>, Disposable) - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Atomically tries to set the given Disposable on the field if it is null or disposes it if the field contains DisposableHelper.DISPOSED.

U

unbounded - Variable in class io.reactivex.internal.subscriptions.SubscriptionArbiter
 
UndeliverableException - Exception in io.reactivex.exceptions
Wrapper for Throwable errors that are sent to `RxJavaPlugins.onError`.
UndeliverableException(Throwable) - Constructor for exception io.reactivex.exceptions.UndeliverableException
Construct an instance by wrapping the given, non-null cause Throwable.
UnicastProcessor<T> - Class in io.reactivex.processors
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> - Class in io.reactivex.subjects
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 unsubscribes.
unit() - Method in class io.reactivex.schedulers.Timed
Returns the time unit of the contained time.
unsafeCreate(CompletableSource) - Static method in class io.reactivex.Completable
Constructs a Completable instance by wrapping the given source callback without any safeguards; you should manage the lifecycle and response to downstream cancellation/dispose.
unsafeCreate(Publisher<T>) - Static method in class io.reactivex.Flowable
Create a Flowable by wrapping a Publisher which has to be implemented according to the Reactive-Streams specification by handling backpressure and cancellation correctly; no safeguards are provided by the Flowable itself.
unsafeCreate(MaybeSource<T>) - Static method in class io.reactivex.Maybe
Advanced use only: creates a Maybe instance without any safeguards by using a callback that is called with a MaybeObserver.
unsafeCreate(ObservableSource<T>) - Static method in class io.reactivex.Observable
Create an Observable by wrapping an ObservableSource which has to be implemented according to the Reactive-Streams-based Observable specification by handling cancellation correctly; no safeguards are provided by the Observable itself.
unsafeCreate(SingleSource<T>) - Static method in class io.reactivex.Single
Advanced use only: creates a Single instance without any safeguards by using a callback that is called with a SingleObserver.
unsubscribeOn(Scheduler) - Method in class io.reactivex.Completable
Returns a Completable which makes sure when a subscriber cancels the subscription, the dispose is called on the specified scheduler.
unsubscribeOn(Scheduler) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that subscribers will cancel it on a specified Scheduler.
unsubscribeOn(Scheduler) - Method in class io.reactivex.Maybe
Returns a Maybe which makes sure when a MaybeObserver disposes the Disposable, that call is propagated up on the specified scheduler.
unsubscribeOn(Scheduler) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that subscribers will dispose it on a specified Scheduler.
unsubscribeOn(Scheduler) - Method in class io.reactivex.Single
Returns a Single which makes sure when a SingleObserver disposes the Disposable, that call is propagated up on the specified scheduler.
update(Disposable) - Method in class io.reactivex.internal.disposables.SequentialDisposable
Atomically: set the next disposable on this container and dispose the previous one (if any) or dispose next if the container has been disposed.
using(Callable<R>, Function<? super R, ? extends CompletableSource>, Consumer<? super R>) - Static method in class io.reactivex.Completable
Returns a Completable instance which manages a resource along with a custom Completable instance while the subscription is active.
using(Callable<R>, Function<? super R, ? extends CompletableSource>, Consumer<? super R>, boolean) - Static method in class io.reactivex.Completable
Returns a Completable instance which manages a resource along with a custom Completable instance while the subscription is active and performs eager or lazy resource disposition.
using(Callable<? extends D>, Function<? super D, ? extends Publisher<? extends T>>, Consumer<? super D>) - Static method in class io.reactivex.Flowable
Constructs a Publisher that creates a dependent resource object which is disposed of on cancellation.
using(Callable<? extends D>, Function<? super D, ? extends Publisher<? extends T>>, Consumer<? super D>, boolean) - Static method in class io.reactivex.Flowable
Constructs a Publisher that creates a dependent resource object which is disposed of just before termination if you have set disposeEagerly to true and cancellation does not occur before termination.
using(Callable<? extends D>, Function<? super D, ? extends MaybeSource<? extends T>>, Consumer<? super D>) - Static method in class io.reactivex.Maybe
Constructs a Maybe that creates a dependent resource object which is disposed of when the upstream terminates or the downstream calls dispose().
using(Callable<? extends D>, Function<? super D, ? extends MaybeSource<? extends T>>, Consumer<? super D>, boolean) - Static method in class io.reactivex.Maybe
Constructs a Maybe that creates a dependent resource object which is disposed of just before termination if you have set disposeEagerly to true and a downstream dispose() does not occur before termination.
using(Callable<? extends D>, Function<? super D, ? extends ObservableSource<? extends T>>, Consumer<? super D>) - Static method in class io.reactivex.Observable
Constructs an ObservableSource that creates a dependent resource object which is disposed of when the downstream calls dispose().
using(Callable<? extends D>, Function<? super D, ? extends ObservableSource<? extends T>>, Consumer<? super D>, boolean) - Static method in class io.reactivex.Observable
Constructs an ObservableSource that creates a dependent resource object which is disposed of just before termination if you have set disposeEagerly to true and a dispose() call does not occur before termination.
using(Callable<U>, Function<? super U, ? extends SingleSource<? extends T>>, Consumer<? super U>) - Static method in class io.reactivex.Single
Allows using and disposing a resource while running a SingleSource instance generated from that resource (similar to a try-with-resources).
using(Callable<U>, Function<? super U, ? extends SingleSource<? extends T>>, Consumer<? super U>, boolean) - Static method in class io.reactivex.Single
Allows using and disposing a resource while running a SingleSource instance generated from that resource (similar to a try-with-resources).

V

validate(Disposable, Disposable) - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Verifies that current is null, next is not null, otherwise signals errors to the RxJavaPlugins and returns false.
validate(Subscription, Subscription) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Verifies that current is null, next is not null, otherwise signals errors to the RxJavaPlugins and returns false.
validate(long) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Validates that the n is positive.
validate(Disposable, Disposable, Class<?>) - Static method in class io.reactivex.internal.util.EndConsumerHelper
Ensures that the upstream Disposable is null and returns true, otherwise disposes the next Disposable and if the upstream is not the shared disposed instance, reports a ProtocolViolationException due to multiple subscribe attempts.
validate(Subscription, Subscription, Class<?>) - Static method in class io.reactivex.internal.util.EndConsumerHelper
Ensures that the upstream Subscription is null and returns true, otherwise cancels the next Subscription and if the upstream is not the shared cancelled instance, reports a ProtocolViolationException due to multiple subscribe attempts.
validate(Subscriber<?>[]) - Method in class io.reactivex.parallel.ParallelFlowable
Validates the number of subscribers and returns true if their number matches the parallelism level of this ParallelFlowable.
value - Variable in class io.reactivex.internal.observers.DeferredScalarDisposable
The value stored temporarily when in fusion mode.
value - Variable in class io.reactivex.internal.subscribers.SinglePostCompleteSubscriber
The last value stored in case there is no request for it.
value - Variable in class io.reactivex.internal.subscriptions.DeferredScalarSubscription
The value is stored here if there is no request yet or in fusion mode.
value() - Method in class io.reactivex.schedulers.Timed
Returns the contained value.
valueAndClass(Object) - Static method in class io.reactivex.observers.BaseTestConsumer
Appends the class name to a non-null value.
valueCount() - Method in class io.reactivex.observers.BaseTestConsumer
Returns the number of onNext values received.
valueOf(String) - Static method in enum io.reactivex.annotations.BackpressureKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.BackpressureOverflowStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.BackpressureStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.operators.flowable.FlowableInternalHelper.RequestMax
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.operators.maybe.MaybeToPublisher
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.subscriptions.EmptySubscription
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.util.ArrayListSupplier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.util.EmptyComponent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.util.ErrorMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.util.HashMapSupplier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.util.ListAddBiConsumer
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.internal.util.NotificationLite
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.observers.BaseTestConsumer.TestWaitStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.reactivex.parallel.ParallelFailureHandling
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.reactivex.annotations.BackpressureKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.BackpressureOverflowStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.BackpressureStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.disposables.DisposableHelper
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.disposables.EmptyDisposable
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.operators.flowable.FlowableInternalHelper.RequestMax
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.operators.maybe.MaybeToPublisher
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.subscriptions.EmptySubscription
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.subscriptions.SubscriptionHelper
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.util.ArrayListSupplier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.util.EmptyComponent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.util.ErrorMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.util.HashMapSupplier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.util.ListAddBiConsumer
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.internal.util.NotificationLite
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.reactivex.observers.BaseTestConsumer.TestWaitStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class io.reactivex.observers.BaseTestConsumer
The list of values received.
values() - Method in class io.reactivex.observers.BaseTestConsumer
Returns a shared list of received onNext values.
values() - Static method in enum io.reactivex.parallel.ParallelFailureHandling
Returns an array containing the constants of this enum type, in the order they are declared.
verifyNonBlocking() - Static method in class io.reactivex.internal.util.BlockingHelper
Checks if the failOnNonBlockingScheduler plugin setting is enabled and the current thread is a Scheduler sensitive to blocking operators.
verifyPositive(int, String) - Static method in class io.reactivex.internal.functions.ObjectHelper
Validate that the given value is positive or report an IllegalArgumentException with the parameter name.
verifyPositive(long, String) - Static method in class io.reactivex.internal.functions.ObjectHelper
Validate that the given value is positive or report an IllegalArgumentException with the parameter name.
VolatileSizeArrayList<T> - Class in io.reactivex.internal.util
Tracks the current underlying array size in a volatile field.
VolatileSizeArrayList() - Constructor for class io.reactivex.internal.util.VolatileSizeArrayList
 
VolatileSizeArrayList(int) - Constructor for class io.reactivex.internal.util.VolatileSizeArrayList
 

W

when(Function<Flowable<Flowable<Completable>>, Completable>) - Method in class io.reactivex.Scheduler
Allows the use of operators for controlling the timing around when actions scheduled on workers are actually done.
window(long) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, long) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, long, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, long, TimeUnit, Scheduler, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, TimeUnit, long) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, TimeUnit, long, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, TimeUnit, Scheduler, long) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, TimeUnit, Scheduler, long, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long, TimeUnit, Scheduler, long, boolean, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(Publisher<B>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits non-overlapping windows of items it collects from the source Publisher where the boundary of each window is determined by the items emitted from a specified boundary-governing Publisher.
window(Publisher<B>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits non-overlapping windows of items it collects from the source Publisher where the boundary of each window is determined by the items emitted from a specified boundary-governing Publisher.
window(Publisher<U>, Function<? super U, ? extends Publisher<V>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(Publisher<U>, Function<? super U, ? extends Publisher<V>>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(Callable<? extends Publisher<B>>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(Callable<? extends Publisher<B>>, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits windows of items it collects from the source Publisher.
window(long) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, long) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, long, int) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, long, TimeUnit, Scheduler, int) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, TimeUnit) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, TimeUnit, long) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, TimeUnit, long, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, TimeUnit, Scheduler, long) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, TimeUnit, Scheduler, long, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(long, TimeUnit, Scheduler, long, boolean, int) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(ObservableSource<B>) - Method in class io.reactivex.Observable
Returns an Observable that emits non-overlapping windows of items it collects from the source ObservableSource where the boundary of each window is determined by the items emitted from a specified boundary-governing ObservableSource.
window(ObservableSource<B>, int) - Method in class io.reactivex.Observable
Returns an Observable that emits non-overlapping windows of items it collects from the source ObservableSource where the boundary of each window is determined by the items emitted from a specified boundary-governing ObservableSource.
window(ObservableSource<U>, Function<? super U, ? extends ObservableSource<V>>) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(ObservableSource<U>, Function<? super U, ? extends ObservableSource<V>>, int) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(Callable<? extends ObservableSource<B>>) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
window(Callable<? extends ObservableSource<B>>, int) - Method in class io.reactivex.Observable
Returns an Observable that emits windows of items it collects from the source ObservableSource.
withLatestFrom(Publisher<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Flowable
Merges the specified Publisher into this Publisher sequence by using the resultSelector function only when the source Publisher (this instance) emits an item.
withLatestFrom(Publisher<T1>, Publisher<T2>, Function3<? super T, ? super T1, ? super T2, R>) - Method in class io.reactivex.Flowable
Combines the value emission from this Publisher with the latest emissions from the other Publishers via a function to produce the output item.
withLatestFrom(Publisher<T1>, Publisher<T2>, Publisher<T3>, Function4<? super T, ? super T1, ? super T2, ? super T3, R>) - Method in class io.reactivex.Flowable
Combines the value emission from this Publisher with the latest emissions from the other Publishers via a function to produce the output item.
withLatestFrom(Publisher<T1>, Publisher<T2>, Publisher<T3>, Publisher<T4>, Function5<? super T, ? super T1, ? super T2, ? super T3, ? super T4, R>) - Method in class io.reactivex.Flowable
Combines the value emission from this Publisher with the latest emissions from the other Publishers via a function to produce the output item.
withLatestFrom(Publisher<?>[], Function<? super Object[], R>) - Method in class io.reactivex.Flowable
Combines the value emission from this Publisher with the latest emissions from the other Publishers via a function to produce the output item.
withLatestFrom(Iterable<? extends Publisher<?>>, Function<? super Object[], R>) - Method in class io.reactivex.Flowable
Combines the value emission from this Publisher with the latest emissions from the other Publishers via a function to produce the output item.
withLatestFrom(ObservableSource<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Observable
Merges the specified ObservableSource into this ObservableSource sequence by using the resultSelector function only when the source ObservableSource (this instance) emits an item.
withLatestFrom(ObservableSource<T1>, ObservableSource<T2>, Function3<? super T, ? super T1, ? super T2, R>) - Method in class io.reactivex.Observable
Combines the value emission from this ObservableSource with the latest emissions from the other ObservableSources via a function to produce the output item.
withLatestFrom(ObservableSource<T1>, ObservableSource<T2>, ObservableSource<T3>, Function4<? super T, ? super T1, ? super T2, ? super T3, R>) - Method in class io.reactivex.Observable
Combines the value emission from this ObservableSource with the latest emissions from the other ObservableSources via a function to produce the output item.
withLatestFrom(ObservableSource<T1>, ObservableSource<T2>, ObservableSource<T3>, ObservableSource<T4>, Function5<? super T, ? super T1, ? super T2, ? super T3, ? super T4, R>) - Method in class io.reactivex.Observable
Combines the value emission from this ObservableSource with the latest emissions from the other ObservableSources via a function to produce the output item.
withLatestFrom(ObservableSource<?>[], Function<? super Object[], R>) - Method in class io.reactivex.Observable
Combines the value emission from this ObservableSource with the latest emissions from the other ObservableSources via a function to produce the output item.
withLatestFrom(Iterable<? extends ObservableSource<?>>, Function<? super Object[], R>) - Method in class io.reactivex.Observable
Combines the value emission from this ObservableSource with the latest emissions from the other ObservableSources via a function to produce the output item.
withTag(CharSequence) - Method in class io.reactivex.observers.BaseTestConsumer
Set the tag displayed along with an assertion failure's other state information.
Worker() - Constructor for class io.reactivex.Scheduler.Worker
 
wrap(CompletableSource) - Static method in class io.reactivex.Completable
Wraps the given CompletableSource into a Completable if not already Completable.
wrap(MaybeSource<T>) - Static method in class io.reactivex.Maybe
Wraps a MaybeSource instance into a new Maybe instance if not already a Maybe instance.
wrap(ObservableSource<T>) - Static method in class io.reactivex.Observable
Wraps an ObservableSource into an Observable if not already an Observable.
wrap(SingleSource<T>) - Static method in class io.reactivex.Single
Wraps a SingleSource instance into a new Single instance if not already a Single instance.
wrapOrThrow(Throwable) - Static method in class io.reactivex.internal.util.ExceptionHelper
If the provided Throwable is an Error this method throws it, otherwise returns a RuntimeException wrapping the error if that error is a checked exception.

Z

zip(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an Iterable of other Publishers.
zip(Publisher<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of n items emitted, in sequence, by the n Publishers emitted by a specified Publisher.
zip(Publisher<? extends T1>, Publisher<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of two items emitted, in sequence, by two other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>, boolean) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of two items emitted, in sequence, by two other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>, boolean, int) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of two items emitted, in sequence, by two other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of three items emitted, in sequence, by three other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of four items emitted, in sequence, by four other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of five items emitted, in sequence, by five other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of six items emitted, in sequence, by six other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of seven items emitted, in sequence, by seven other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of eight items emitted, in sequence, by eight other Publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Publisher<? extends T9>, Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of nine items emitted, in sequence, by nine other Publishers.
zip(Iterable<? extends MaybeSource<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an Iterable of other MaybeSources.
zip(MaybeSource<? extends T1>, MaybeSource<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of two items emitted, in sequence, by two other MaybeSources.
zip(MaybeSource<? extends T1>, MaybeSource<? extends T2>, MaybeSource<? extends T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of three items emitted, in sequence, by three other MaybeSources.
zip(MaybeSource<? extends T1>, MaybeSource<? extends T2>, MaybeSource<? extends T3>, MaybeSource<? extends T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of four items emitted, in sequence, by four other MaybeSources.
zip(MaybeSource<? extends T1>, MaybeSource<? extends T2>, MaybeSource<? extends T3>, MaybeSource<? extends T4>, MaybeSource<? extends T5>, Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of five items emitted, in sequence, by five other MaybeSources.
zip(MaybeSource<? extends T1>, MaybeSource<? extends T2>, MaybeSource<? extends T3>, MaybeSource<? extends T4>, MaybeSource<? extends T5>, MaybeSource<? extends T6>, Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of six items emitted, in sequence, by six other MaybeSources.
zip(MaybeSource<? extends T1>, MaybeSource<? extends T2>, MaybeSource<? extends T3>, MaybeSource<? extends T4>, MaybeSource<? extends T5>, MaybeSource<? extends T6>, MaybeSource<? extends T7>, Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of seven items emitted, in sequence, by seven other MaybeSources.
zip(MaybeSource<? extends T1>, MaybeSource<? extends T2>, MaybeSource<? extends T3>, MaybeSource<? extends T4>, MaybeSource<? extends T5>, MaybeSource<? extends T6>, MaybeSource<? extends T7>, MaybeSource<? extends T8>, Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of eight items emitted, in sequence, by eight other MaybeSources.
zip(MaybeSource<? extends T1>, MaybeSource<? extends T2>, MaybeSource<? extends T3>, MaybeSource<? extends T4>, MaybeSource<? extends T5>, MaybeSource<? extends T6>, MaybeSource<? extends T7>, MaybeSource<? extends T8>, MaybeSource<? extends T9>, Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of nine items emitted, in sequence, by nine other MaybeSources.
zip(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an Iterable of other ObservableSources.
zip(ObservableSource<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of n items emitted, in sequence, by the n ObservableSources emitted by a specified ObservableSource.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of two items emitted, in sequence, by two other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>, boolean) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of two items emitted, in sequence, by two other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>, boolean, int) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of two items emitted, in sequence, by two other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of three items emitted, in sequence, by three other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of four items emitted, in sequence, by four other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of five items emitted, in sequence, by five other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of six items emitted, in sequence, by six other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of seven items emitted, in sequence, by seven other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, ObservableSource<? extends T8>, Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of eight items emitted, in sequence, by eight other ObservableSources.
zip(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, ObservableSource<? extends T8>, ObservableSource<? extends T9>, Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of nine items emitted, in sequence, by nine other ObservableSources.
zip(Iterable<? extends SingleSource<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.Single
Waits until all SingleSource sources provided by the Iterable sequence signal a success value and calls a zipper function with an array of these values to return a result to be emitted to downstream.
zip(SingleSource<? extends T1>, SingleSource<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.Single
Returns a Single that emits the results of a specified combiner function applied to two items emitted by two other Singles.
zip(SingleSource<? extends T1>, SingleSource<? extends T2>, SingleSource<? extends T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class io.reactivex.Single
Returns a Single that emits the results of a specified combiner function applied to three items emitted by three other Singles.
zip(SingleSource<? extends T1>, SingleSource<? extends T2>, SingleSource<? extends T3>, SingleSource<? extends T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class io.reactivex.Single
Returns a Single that emits the results of a specified combiner function applied to four items emitted by four other Singles.
zip(SingleSource<? extends T1>, SingleSource<? extends T2>, SingleSource<? extends T3>, SingleSource<? extends T4>, SingleSource<? extends T5>, Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class io.reactivex.Single
Returns a Single that emits the results of a specified combiner function applied to five items emitted by five other Singles.
zip(SingleSource<? extends T1>, SingleSource<? extends T2>, SingleSource<? extends T3>, SingleSource<? extends T4>, SingleSource<? extends T5>, SingleSource<? extends T6>, Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class io.reactivex.Single
Returns a Single that emits the results of a specified combiner function applied to six items emitted by six other Singles.
zip(SingleSource<? extends T1>, SingleSource<? extends T2>, SingleSource<? extends T3>, SingleSource<? extends T4>, SingleSource<? extends T5>, SingleSource<? extends T6>, SingleSource<? extends T7>, Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class io.reactivex.Single
Returns a Single that emits the results of a specified combiner function applied to seven items emitted by seven other Singles.
zip(SingleSource<? extends T1>, SingleSource<? extends T2>, SingleSource<? extends T3>, SingleSource<? extends T4>, SingleSource<? extends T5>, SingleSource<? extends T6>, SingleSource<? extends T7>, SingleSource<? extends T8>, Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class io.reactivex.Single
Returns a Single that emits the results of a specified combiner function applied to eight items emitted by eight other Singles.
zip(SingleSource<? extends T1>, SingleSource<? extends T2>, SingleSource<? extends T3>, SingleSource<? extends T4>, SingleSource<? extends T5>, SingleSource<? extends T6>, SingleSource<? extends T7>, SingleSource<? extends T8>, SingleSource<? extends T9>, Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class io.reactivex.Single
Returns a Single that emits the results of a specified combiner function applied to nine items emitted by nine other Singles.
zipArray(Function<? super Object[], ? extends R>, boolean, int, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an array of other Publishers.
zipArray(Function<? super Object[], ? extends R>, MaybeSource<? extends T>...) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an array of other MaybeSources.
zipArray(Function<? super Object[], ? extends R>, boolean, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an array of other ObservableSources.
zipArray(Function<? super Object[], ? extends R>, SingleSource<? extends T>...) - Static method in class io.reactivex.Single
Waits until all SingleSource sources provided via an array signal a success value and calls a zipper function with an array of these values to return a result to be emitted to downstream.
zipIterable(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>, boolean, int) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an Iterable of other Publishers.
zipIterable(Function<? super Object[], ? extends R>) - Static method in class io.reactivex.internal.operators.flowable.FlowableInternalHelper
 
zipIterable(Function<? super Object[], ? extends R>) - Static method in class io.reactivex.internal.operators.observable.ObservableInternalHelper
 
zipIterable(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>, boolean, int) - Static method in class io.reactivex.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an Iterable of other ObservableSources.
zipWith(Iterable<U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the result of applying a specified function to pairs of values, one each from the source Publisher and a specified Iterable sequence.
zipWith(Publisher<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the result of applying a specified function to pairs of values, one each from the source Publisher and another specified Publisher.
zipWith(Publisher<? extends U>, BiFunction<? super T, ? super U, ? extends R>, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the result of applying a specified function to pairs of values, one each from the source Publisher and another specified Publisher.
zipWith(Publisher<? extends U>, BiFunction<? super T, ? super U, ? extends R>, boolean, int) - Method in class io.reactivex.Flowable
Returns a Flowable that emits items that are the result of applying a specified function to pairs of values, one each from the source Publisher and another specified Publisher.
zipWith(MaybeSource<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Maybe
Waits until this and the other MaybeSource signal a success value then applies the given BiFunction to those values and emits the BiFunction's resulting value to downstream.
zipWith(Iterable<U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the result of applying a specified function to pairs of values, one each from the source ObservableSource and a specified Iterable sequence.
zipWith(ObservableSource<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the result of applying a specified function to pairs of values, one each from the source ObservableSource and another specified ObservableSource.
zipWith(ObservableSource<? extends U>, BiFunction<? super T, ? super U, ? extends R>, boolean) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the result of applying a specified function to pairs of values, one each from the source ObservableSource and another specified ObservableSource.
zipWith(ObservableSource<? extends U>, BiFunction<? super T, ? super U, ? extends R>, boolean, int) - Method in class io.reactivex.Observable
Returns an Observable that emits items that are the result of applying a specified function to pairs of values, one each from the source ObservableSource and another specified ObservableSource.
zipWith(SingleSource<U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.Single
Returns a Single that emits the result of applying a specified function to the pair of items emitted by the source Single and another specified Single.
A B C D E F G H I J K L M N O P Q R S T U V W Z 
Skip navigation links
RxJava 2.1.16.redhat-00001

Copyright © 2018 JBoss by Red Hat. All rights reserved.