Movatterモバイル変換


[0]ホーム

URL:


Skip navigation links
A B C D E F G H I J L M N O P 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.
Action - Interface inio.reactivex.functions
A functional interface similar to Runnable but allows throwing a checked exception.
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 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.
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.
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.
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 disposes 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 (disposing 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 (disposing 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 disposes 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 (disposing 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 (disposing 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 thenext 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 thenext 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 thenext SingleSource.
andThen(MaybeSource<T>) - Method in class io.reactivex.Completable
Returns aMaybe which will subscribe to this Completable and once that is completed then will subscribe to thenext 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 emitstrue if any item emitted by the source Publisher satisfies a specified condition, otherwisefalse.
any(Predicate<? super T>) - Method in class io.reactivex.Observable
Returns a Single that emitstrue if any item emitted by the source ObservableSource satisfies a specified condition, otherwisefalse.
apply(Completable) - Method in interface io.reactivex.CompletableConverter
Applies a function to the upstream Completable and returns a converted value of typeR.
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 typeR.
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(Maybe<T>) - Method in interface io.reactivex.MaybeConverter
Applies a function to the upstream Maybe and returns a converted value of typeR.
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 typeR.
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 typeR.
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 typeR.
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.
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.
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 items that are in the specified collection as well, irrespective of the order they were received.
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.
AsyncProcessor<T> - Class inio.reactivex.processors
Processor that emits the very last value followed by a completion event or the received error toSubscribers.
AsyncSubject<T> - Class inio.reactivex.subjects
A Subject that emits the very last value followed by a completion event or the received error to Observers.
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.
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

BackpressureKind - Enum inio.reactivex.annotations
Enumeration for various kinds of backpressure support.
BackpressureOverflowStrategy - Enum inio.reactivex
Options to deal with buffer overflow when using onBackpressureBuffer.
BackpressureStrategy - Enum inio.reactivex
Represents the options for applying backpressure to a source sequence.
BackpressureSupport - Annotation Type inio.reactivex.annotations
Indicates the backpressure support kind of the associated operator or class.
BaseTestConsumer<T,U extendsBaseTestConsumer<T,U>> - Class inio.reactivex.observers
Base class with shared infrastructure to support TestSubscriber and TestObserver.
BaseTestConsumer() - Constructor for class io.reactivex.observers.BaseTestConsumer
 
BaseTestConsumer.TestWaitStrategy - Enum inio.reactivex.observers
Enumeration of default wait strategies when waiting for a specific number of items inBaseTestConsumer.awaitCount(int, Runnable).
BehaviorProcessor<T> - Class inio.reactivex.processors
Processor that emits the most recent item it has observed and all subsequent observed items to each subscribedSubscriber.
BehaviorSubject<T> - Class inio.reactivex.subjects
Subject that emits the most recent item it has observed and all subsequent observed items to each subscribedObserver.
Beta - Annotation Type inio.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 inio.reactivex.functions
A functional interface (callback) that accepts two values (of possibly different types).
BiFunction<T1,T2,R> - Interface inio.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
BiPredicate<T1,T2> - Interface inio.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.
blockingFirst() - Method in class io.reactivex.Flowable
Returns the first item emitted by thisFlowable, or throwsNoSuchElementException if it emits no items.
blockingFirst(T) - Method in class io.reactivex.Flowable
Returns the first item emitted by thisFlowable, or a default value if it emits no items.
blockingFirst() - Method in class io.reactivex.Observable
Returns the first item emitted by thisObservable, or throwsNoSuchElementException if it emits no items.
blockingFirst(T) - Method in class io.reactivex.Observable
Returns the first item emitted by thisObservable, or a default value if it emits no items.
blockingForEach(Consumer<? super T>) - Method in class io.reactivex.Flowable
Consumes the upstreamFlowable in a blocking fashion and invokes the givenConsumer with each upstream item on thecurrent thread until the upstream terminates.
blockingForEach(Consumer<? super T>) - Method in class io.reactivex.Observable
Consumes the upstreamObservable in a blocking fashion and invokes the givenConsumer with each upstream item on thecurrent 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.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).
blockingIterable() - Method in class io.reactivex.Flowable
Converts thisFlowable into anIterable.
blockingIterable(int) - Method in class io.reactivex.Flowable
Converts thisFlowable into anIterable.
blockingIterable() - Method in class io.reactivex.Observable
Converts thisObservable into anIterable.
blockingIterable(int) - Method in class io.reactivex.Observable
Converts thisObservable into anIterable.
blockingLast() - Method in class io.reactivex.Flowable
Returns the last item emitted by thisFlowable, or throwsNoSuchElementException if thisFlowable emits no items.
blockingLast(T) - Method in class io.reactivex.Flowable
Returns the last item emitted by thisFlowable, or a default value if it emits no items.
blockingLast() - Method in class io.reactivex.Observable
Returns the last item emitted by thisObservable, or throwsNoSuchElementException if thisObservable emits no items.
blockingLast(T) - Method in class io.reactivex.Observable
Returns the last item emitted by thisObservable, or a default value if it emits no items.
blockingLatest() - Method in class io.reactivex.Flowable
Returns anIterable that returns the latest item emitted by thisFlowable, waiting if necessary for one to become available.
blockingLatest() - Method in class io.reactivex.Observable
Returns anIterable that returns the latest item emitted by thisObservable, waiting if necessary for one to become available.
blockingMostRecent(T) - Method in class io.reactivex.Flowable
Returns anIterable that always returns the item most recently emitted by thisFlowable.
blockingMostRecent(T) - Method in class io.reactivex.Observable
Returns anIterable that always returns the item most recently emitted by thisObservable.
blockingNext() - Method in class io.reactivex.Flowable
Returns anIterable that blocks until thisFlowable emits another item, then returns that item.
blockingNext() - Method in class io.reactivex.Observable
Returns anIterable that blocks until thisObservable emits another item, then returns that item.
blockingSingle() - Method in class io.reactivex.Flowable
If thisFlowable completes after emitting a single item, return that item, otherwise throw aNoSuchElementException.
blockingSingle(T) - Method in class io.reactivex.Flowable
If thisFlowable completes after emitting a single item, return that item; if it emits more than one item, throw anIllegalArgumentException; if it emits no items, return a default value.
blockingSingle() - Method in class io.reactivex.Observable
If thisObservable completes after emitting a single item, return that item, otherwise throw aNoSuchElementException.
blockingSingle(T) - Method in class io.reactivex.Observable
If thisObservable completes after emitting a single item, return that item; if it emits more than one item, throw anIllegalArgumentException; 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 callbackson the current thread.
blockingSubscribe(Consumer<? super T>, int) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the given callbackson the current thread.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Flowable
Subscribes to the source and calls the given callbackson 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 callbackson 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 callbackson 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 callbackson the current thread.
blockingSubscribe(Subscriber<? super T>) - Method in class io.reactivex.Flowable
Subscribes to the source and calls theSubscriber methodson 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 callbackson the current thread.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.Observable
Subscribes to the source and calls the given callbackson 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 callbackson the current thread.
blockingSubscribe(Observer<? super T>) - Method in class io.reactivex.Observable
Subscribes to the source and calls theObserver methodson the current thread.
BooleanSupplier - Interface inio.reactivex.functions
A functional interface (callback) that returns a boolean value.
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.
cancel() - Method in interface io.reactivex.functions.Cancellable
Cancel the action or free a resource.
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 inio.reactivex.functions
A functional interface that has a single cancel method that can throw.
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.
CheckReturnValue - Annotation Type inio.reactivex.annotations
Marks methods whose return values should be checked.
checkSubscriptionOnce - Variable in class io.reactivex.observers.BaseTestConsumer
 
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.
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.
Completable - Class inio.reactivex
TheCompletable class represents a deferred computation without any value but only indication for completion or exception.
Completable() - Constructor for class io.reactivex.Completable
 
CompletableConverter<R> - Interface inio.reactivex
Convenience interface and callback used by theCompletable.as(io.reactivex.CompletableConverter<? extends R>) operator to turn a Completable into another value fluently.
CompletableEmitter - Interface inio.reactivex
Abstraction over an RxJavaCompletableObserver that allows associating a resource with it.
CompletableObserver - Interface inio.reactivex
Provides a mechanism for receiving push-based notification of a valueless completion or an error.
CompletableOnSubscribe - Interface inio.reactivex
A functional interface that has asubscribe() method that receives an instance of aCompletableEmitter instance that allows pushing an event in a cancellation-safe manner.
CompletableOperator - Interface inio.reactivex
Interface to map/wrap a downstream observer to an upstream observer.
CompletableSource - Interface inio.reactivex
Represents a basicCompletable source base interface, consumable via anCompletableObserver.
CompletableSubject - Class inio.reactivex.subjects
Represents a hot Completable-like source and consumer of events similar to Subjects.
CompletableTransformer - Interface inio.reactivex
Convenience interface and callback used by the compose operator to turn a Completable into another Completable fluently.
complete() - Static method in class io.reactivex.Completable
Returns a Completable instance that completes immediately when subscribed to.
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.
CompositeDisposable - Class inio.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 inio.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'scomputation scheduler or takes timing information from it.
computation() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, sharedScheduler instance intended for computational work.
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 an array of Publishers eagerly into a single stream of values.
concatArrayEager(int, int, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Concatenates an array 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 an array of ObservableSources eagerly into a single stream of values.
concatArrayEager(int, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Concatenates an array 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.
concatArrayEagerDelayError(Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Concatenates an array ofPublishers eagerly into a single stream of values and delaying any errors until all sources terminate.
concatArrayEagerDelayError(int, int, Publisher<? extends T>...) - Static method in class io.reactivex.Flowable
Concatenates an array ofPublishers eagerly into a single stream of values and delaying any errors until all sources terminate.
concatArrayEagerDelayError(ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Concatenates an array ofObservableSources eagerly into a single stream of values and delaying any errors until all sources terminate.
concatArrayEagerDelayError(int, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.Observable
Concatenates an array ofObservableSources eagerly into a single stream of values and delaying any errors until all sources terminate.
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 intoCompletableSources 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 intoCompletableSources 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 intoCompletableSources and subscribes to them one after the other terminates, delaying all errors till both thisFlowable and all innerCompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean) - Method in class io.reactivex.Flowable
Maps the upstream items intoCompletableSources and subscribes to them one after the other terminates, optionally delaying all errors till both thisFlowable and all innerCompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean, int) - Method in class io.reactivex.Flowable
Maps the upstream items intoCompletableSources and subscribes to them one after the other terminates, optionally delaying all errors till both thisFlowable and all innerCompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Observable
Maps the upstream items intoCompletableSources and subscribes to them one after the other terminates, delaying all errors till both thisObservable and all innerCompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean) - Method in class io.reactivex.Observable
Maps the upstream items intoCompletableSources and subscribes to them one after the other terminates, optionally delaying all errors till both thisObservable and all innerCompletableSources terminate.
concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean, int) - Method in class io.reactivex.Observable
Maps the upstream items intoCompletableSources and subscribes to them one after the other terminates, optionally delaying all errors till both thisObservable and all innerCompletableSources 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 intoMaybeSources and subscribes to them one after the other succeeds or completes, emits their success value if available or terminates immediately if either thisFlowable or the current innerMaybeSource fail.
concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, int) - Method in class io.reactivex.Flowable
Maps the upstream items intoMaybeSources and subscribes to them one after the other succeeds or completes, emits their success value if available or terminates immediately if either thisFlowable or the current innerMaybeSource fail.
concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items intoMaybeSources and subscribes to them one after the other succeeds or completes, emits their success value if available or terminates immediately if either thisObservable or the current innerMaybeSource fail.
concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, int) - Method in class io.reactivex.Observable
Maps the upstream items intoMaybeSources and subscribes to them one after the other succeeds or completes, emits their success value if available or terminates immediately if either thisObservable or the current innerMaybeSource fail.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items intoMaybeSources and subscribes to them one after the other terminates, emits their success value if available and delaying all errors till both thisFlowable and all innerMaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Method in class io.reactivex.Flowable
Maps the upstream items intoMaybeSources and subscribes to them one after the other terminates, emits their success value if available and optionally delaying all errors till both thisFlowable and all innerMaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean, int) - Method in class io.reactivex.Flowable
Maps the upstream items intoMaybeSources and subscribes to them one after the other terminates, emits their success value if available and optionally delaying all errors till both thisFlowable and all innerMaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items intoMaybeSources and subscribes to them one after the other terminates, emits their success value if available and delaying all errors till both thisObservable and all innerMaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Method in class io.reactivex.Observable
Maps the upstream items intoMaybeSources and subscribes to them one after the other terminates, emits their success value if available and optionally delaying all errors till both thisObservable and all innerMaybeSources terminate.
concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean, int) - Method in class io.reactivex.Observable
Maps the upstream items intoMaybeSources and subscribes to them one after the other terminates, emits their success value if available and optionally delaying all errors till both thisObservable and all innerMaybeSources terminate.
concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds, emits their success values or terminates immediately if either thisFlowable or the current innerSingleSource fail.
concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, int) - Method in class io.reactivex.Flowable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds, emits their success values or terminates immediately if either thisFlowable or the current innerSingleSource fail.
concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds, emits their success values or terminates immediately if either thisObservable or the current innerSingleSource fail.
concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, int) - Method in class io.reactivex.Observable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds, emits their success values or terminates immediately if either thisObservable or the current innerSingleSource fail.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds or fails, emits their success values and delays all errors till both thisFlowable and all innerSingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Method in class io.reactivex.Flowable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds or fails, emits their success values and optionally delays all errors till both thisFlowable and all innerSingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean, int) - Method in class io.reactivex.Flowable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds or fails, emits their success values and optionally delays errors till both thisFlowable and all innerSingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds or fails, emits their success values and delays all errors till both thisObservable and all innerSingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Method in class io.reactivex.Observable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds or fails, emits their success values and optionally delays all errors till both thisObservable and all innerSingleSources terminate.
concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean, int) - Method in class io.reactivex.Observable
Maps the upstream items intoSingleSources and subscribes to them one after the other succeeds or fails, emits their success values and optionally delays errors till both thisObservable and all innerSingleSources 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 aFlowable that emits the items from thisFlowable followed by the success item or error event of the otherSingleSource.
concatWith(MaybeSource<? extends T>) - Method in class io.reactivex.Flowable
Returns aFlowable that emits the items from thisFlowable followed by the success item or terminal events of the otherMaybeSource.
concatWith(CompletableSource) - Method in class io.reactivex.Flowable
Returns aFlowable that emits items from thisFlowable and when it completes normally, the otherCompletableSource is subscribed to and the returnedFlowable 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 anObservable that emits the items from thisObservable followed by the success item or error event of the otherSingleSource.
concatWith(MaybeSource<? extends T>) - Method in class io.reactivex.Observable
Returns anObservable that emits the items from thisObservable followed by the success item or terminal events of the otherMaybeSource.
concatWith(CompletableSource) - Method in class io.reactivex.Observable
Returns anObservable that emits items from thisObservable and when it completes normally, the otherCompletableSource is subscribed to and the returnedObservable 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.
connect(Consumer<? super Disposable>) - Method in class io.reactivex.flowables.ConnectableFlowable
Instructs theConnectableFlowable to begin emitting the items from its underlyingFlowable to itsSubscribers.
connect() - Method in class io.reactivex.flowables.ConnectableFlowable
Instructs theConnectableFlowable to begin emitting the items from its underlyingFlowable to itsSubscribers.
connect(Consumer<? super Disposable>) - Method in class io.reactivex.observables.ConnectableObservable
Instructs theConnectableObservable to begin emitting the items from its underlyingObservable to itsObservers.
connect() - Method in class io.reactivex.observables.ConnectableObservable
Instructs theConnectableObservable to begin emitting the items from its underlyingObservable to itsObservers.
ConnectableFlowable<T> - Class inio.reactivex.flowables
AConnectableFlowable resembles an ordinaryFlowable, except that it does not begin emitting items when it is subscribed to, but only when itsConnectableFlowable.connect(io.reactivex.functions.Consumer<? super io.reactivex.disposables.Disposable>) method is called.
ConnectableFlowable() - Constructor for class io.reactivex.flowables.ConnectableFlowable
 
ConnectableObservable<T> - Class inio.reactivex.observables
AConnectableObservable resembles an ordinaryObservable, except that it does not begin emitting items when it is subscribed to, but only when itsConnectableObservable.connect(io.reactivex.functions.Consumer<? super io.reactivex.disposables.Disposable>) method is called.
ConnectableObservable() - Constructor for class io.reactivex.observables.ConnectableObservable
 
Consumer<T> - Interface inio.reactivex.functions
A functional interface (callback) that accepts a single value.
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.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.
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 Single 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(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 aBehaviorProcessor 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 Single) 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 aBehaviorSubject 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.
createComputationScheduler(ThreadFactory) - Static method in class io.reactivex.plugins.RxJavaPlugins
Create an instance of the defaultScheduler used forSchedulers.computation() except usingthreadFactory for thread creation.
createDefault(T) - Static method in class io.reactivex.processors.BehaviorProcessor
Creates aBehaviorProcessor that emits the last item it observed and all subsequent items to eachSubscriber that subscribes to it.
createDefault(T) - Static method in class io.reactivex.subjects.BehaviorSubject
Creates aBehaviorSubject that emits the last item it observed and all subsequent items to eachObserver that subscribes to it.
createIoScheduler(ThreadFactory) - Static method in class io.reactivex.plugins.RxJavaPlugins
Create an instance of the defaultScheduler used forSchedulers.io() except usingthreadFactory for thread creation.
createNewThreadScheduler(ThreadFactory) - Static method in class io.reactivex.plugins.RxJavaPlugins
Create an instance of the defaultScheduler used forSchedulers.newThread() except usingthreadFactory 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.
createSingleScheduler(ThreadFactory) - Static method in class io.reactivex.plugins.RxJavaPlugins
Create an instance of the defaultScheduler used forSchedulers.single() except usingthreadFactory 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.Scheduler
Retrieves or creates a newScheduler.Worker that represents sequential execution of actions.
createWorker() - Method in class io.reactivex.schedulers.TestScheduler
 
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 inio.reactivex.observers
Abstract base implementation of anObserver with support for cancelling a subscription viaDefaultObserver.cancel() (synchronously) and callsDefaultObserver.onStart() when the subscription happens.
DefaultObserver() - Constructor for class io.reactivex.observers.DefaultObserver
 
DefaultSubscriber<T> - Class inio.reactivex.subscribers
Abstract base implementation of aSubscriber with support for requesting viaDefaultSubscriber.request(long), cancelling via viaDefaultSubscriber.cancel() (both synchronously) and callsDefaultSubscriber.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 aCallable for each individualSingleObserver to return the actualSingleSource to be subscribed to.
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(long, TimeUnit) - Method in class io.reactivex.Completable
Returns a Completable that delays the subscription to the source CompletableSource by a given amount of time.
delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.Completable
Returns a Completable that delays the subscription to the source CompletableSource by a given amount of time, both waiting and subscribing on a given Scheduler.
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.
dematerialize() - Method in class io.reactivex.Flowable
Deprecated.
in 2.2.4; inherently type-unsafe as it overrides the output generic type. UseFlowable.dematerialize(Function) instead.
dematerialize(Function<? super T, Notification<R>>) - Method in class io.reactivex.Flowable
Returns a Flowable that reverses the effect ofmaterialize by transforming theNotification objects extracted from the source items via a selector function into their respectiveSubscriber signal types.
dematerialize() - Method in class io.reactivex.Observable
Deprecated.
in 2.2.4; inherently type-unsafe as it overrides the output generic type. UseObservable.dematerialize(Function) instead.
dematerialize(Function<? super T, Notification<R>>) - Method in class io.reactivex.Observable
Returns an Observable that reverses the effect ofmaterialize by transforming theNotification objects extracted from the source items via a selector function into their respectiveObserver signal types.
dematerialize(Function<? super T, Notification<R>>) - Method in class io.reactivex.Single
Maps theNotification success value of this Single back into normalonSuccess,onError oronComplete signals as aMaybe source.
Disposable - Interface inio.reactivex.disposables
Represents a disposable resource.
DisposableCompletableObserver - Class inio.reactivex.observers
An abstractCompletableObserver that allows asynchronous cancellation by implementing Disposable.
DisposableCompletableObserver() - Constructor for class io.reactivex.observers.DisposableCompletableObserver
 
DisposableMaybeObserver<T> - Class inio.reactivex.observers
An abstractMaybeObserver that allows asynchronous cancellation by implementing Disposable.
DisposableMaybeObserver() - Constructor for class io.reactivex.observers.DisposableMaybeObserver
 
DisposableObserver<T> - Class inio.reactivex.observers
An abstractObserver that allows asynchronous cancellation by implementing Disposable.
DisposableObserver() - Constructor for class io.reactivex.observers.DisposableObserver
 
Disposables - Class inio.reactivex.disposables
Utility class to help create disposables by wrapping other types.
DisposableSingleObserver<T> - Class inio.reactivex.observers
An abstractSingleObserver that allows asynchronous cancellation by implementing Disposable.
DisposableSingleObserver() - Constructor for class io.reactivex.observers.DisposableSingleObserver
 
DisposableSubscriber<T> - Class inio.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.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 onObject.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 onObject.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 onObject.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 onObject.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 onObject.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 onObject.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 onObject.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 onObject.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 onObject.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 onObject.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 anAction to be called when this Publisher invokes eitheronComplete oronError.
doAfterTerminate(Action) - Method in class io.reactivex.Maybe
Registers anAction to be called when this Maybe invokes eitheronSuccess,onComplete oronError.
doAfterTerminate(Action) - Method in class io.reactivex.Observable
Registers anAction to be called when this ObservableSource invokes eitheronComplete oronError.
doAfterTerminate(Action) - Method in class io.reactivex.Single
Registers anAction 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.observers.BaseTestConsumer
The latch that indicates an onError or onComplete has been called.
doOnCancel(Action) - Method in class io.reactivex.Flowable
Calls the cancelAction 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 callsonComplete.
doOnComplete(Action) - Method in class io.reactivex.Maybe
Modifies the source Maybe so that it invokes an action when it callsonComplete.
doOnComplete(Action) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes an action when it callsonComplete.
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 sharedAction 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 sharedAction 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 disposeAction if the downstream disposes the sequence.
doOnDispose(Action) - Method in class io.reactivex.Single
Calls the sharedAction 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 callsonError.
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 callsonError.
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, disposal).
doOnNext(Consumer<? super T>) - Method in class io.reactivex.Flowable
Modifies the source Publisher so that it invokes an action when it callsonNext.
doOnNext(Consumer<? super T>) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes an action when it callsonNext.
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 givenParallelFailureHandling 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 sourcePublisher 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 sourcePublisher 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 sourceObservableSource 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 callsonComplete oronError.
doOnTerminate(Action) - Method in class io.reactivex.Maybe
Returns a Maybe instance that calls the given onTerminate callback just before this Maybe completes normally or with an exception.
doOnTerminate(Action) - Method in class io.reactivex.Observable
Modifies the source ObservableSource so that it invokes an action when it callsonComplete oronError.
doOnTerminate(Action) - Method in class io.reactivex.Single
Returns a Single instance that calls the given onTerminate callback just before this Single completes normally or with an exception.

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 Single 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 Single that emits the item found at a specified index in a sequence of emissions from this Flowable or signals aNoSuchElementException 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 aNoSuchElementException if this Observable signals fewer elements than index.
Emitter<T> - Interface inio.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 theSubscriber and immediately invokes itsonComplete method.
empty() - Static method in class io.reactivex.Maybe
Returns a (singleton) Maybe instance that callsonComplete immediately.
empty() - Static method in class io.reactivex.Observable
Returns an Observable that emits no items to theObserver and immediately invokes itsonComplete method.
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).
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 aSubscriber'sonError method when the Subscriber subscribes to it.
error(Throwable) - Static method in class io.reactivex.Flowable
Returns a Flowable that invokes aSubscriber'sonError method when the Subscriber subscribes to it.
error(Throwable) - Static method in class io.reactivex.Maybe
Returns a Maybe that invokes a subscriber'sonError method when the subscriber subscribes to it.
error(Callable<? extends Throwable>) - Static method in class io.reactivex.Maybe
Returns a Maybe that invokes aMaybeObserver'sonError method when the MaybeObserver subscribes to it.
error(Callable<? extends Throwable>) - Static method in class io.reactivex.Observable
Returns an Observable that invokes anObserver'sonError method when the Observer subscribes to it.
error(Throwable) - Static method in class io.reactivex.Observable
Returns an Observable that invokes anObserver'sonError 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'sonError method when the subscriber subscribes to it.
errorCount() - Method in class io.reactivex.observers.BaseTestConsumer
Returns the number of onError exceptions received.
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
 
Exceptions - Class inio.reactivex.exceptions
Utility class to help propagate checked exceptions and rethrow exceptions designated as fatal.
Experimental - Annotation Type inio.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(String) - Method in class io.reactivex.observers.BaseTestConsumer
Fail with the given message and add the sequence of errors as suppressed ones.
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 givenParallelFailureHandling 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 aNoSuchElementException 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 aNoSuchElementException 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 aCompletable that completes based on applying a specified function to the item emitted by the sourceMaybe, where that function returns aCompletable.
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 aCompletable that completes based on applying a specified function to the item emitted by the sourceSingle, where that function returns aCompletable.
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 mostmaxConcurrency 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 mostmaxConcurrency 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 aSingle based on applying a specified function to the item emitted by the sourceMaybe, where that function returns aSingle.
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 aMaybe based on applying a specified function to the item emitted by the sourceMaybe, where that function returns aSingle.
flattenAsFlowable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Maybe
Maps the success value of the upstreamMaybe into anIterable and emits its items as aFlowable sequence.
flattenAsFlowable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Single
Maps the success value of the upstreamSingle into anIterable and emits its items as aFlowable sequence.
flattenAsObservable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Maybe
Maps the success value of the upstreamMaybe into anIterable and emits its items as anObservable sequence.
flattenAsObservable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.Single
Maps the success value of the upstreamSingle into anIterable and emits its items as anObservable sequence.
Flowable<T> - Class inio.reactivex
The Flowable class that implements theReactive Streams Pattern and offers factory methods, intermediate operators and the ability to consume reactive dataflows.
Flowable() - Constructor for class io.reactivex.Flowable
 
FlowableConverter<T,R> - Interface inio.reactivex
Convenience interface and callback used by theFlowable.as(io.reactivex.FlowableConverter<T, ? extends R>) operator to turn a Flowable into another value fluently.
FlowableEmitter<T> - Interface inio.reactivex
Abstraction over a Reactive StreamsSubscriber that allows associating a resource with it and exposes the current number of downstream requested amount.
FlowableOnSubscribe<T> - Interface inio.reactivex
A functional interface that has asubscribe() method that receives an instance of aFlowableEmitter instance that allows pushing events in a backpressure-safe and cancellation-safe manner.
FlowableOperator<Downstream,Upstream> - Interface inio.reactivex
Interface to map/wrap a downstream subscriber to an upstream subscriber.
FlowableProcessor<T> - Class inio.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
 
FlowableSubscriber<T> - Interface inio.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.
FlowableTransformer<Upstream,Downstream> - Interface inio.reactivex
Interface to compose Flowables.
forEach(Consumer<? super T>) - Method in class io.reactivex.Flowable
Subscribes to thePublisher and receives notifications for each element.
forEach(Consumer<? super T>) - Method in class io.reactivex.Observable
Subscribes to theObservableSource and receives notifications for each element.
forEachWhile(Predicate<? super T>) - Method in class io.reactivex.Flowable
Subscribes to thePublisher 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 thePublisher 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 thePublisher and receives notifications for each element and the terminal events until the onNext Predicate returns false.
forEachWhile(Predicate<? super T>) - Method in class io.reactivex.Observable
Subscribes to theObservableSource 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 theObservableSource 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 theObservableSource and receives notifications for each element and the terminal events until the onNext Predicate returns false.
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 anExecutor into a new Scheduler instance and delegatesschedule() calls to it.
from(Executor, boolean) - Static method in class io.reactivex.schedulers.Schedulers
Wraps anExecutor into a new Scheduler instance and delegatesschedule() 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 aMaybe that invokes the givenCallable for each individualMaybeObserver that subscribes and emits the resulting non-null item viaonSuccess while considering anull result from theCallable as indication for valueless completion viaonComplete.
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 aSingle 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 aFuture into a Publisher.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class io.reactivex.Flowable
Converts aFuture into a Publisher, with a timeout on the Future.
fromFuture(Future<? extends T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Flowable
Converts aFuture into a Publisher, with a timeout on the Future.
fromFuture(Future<? extends T>, Scheduler) - Static method in class io.reactivex.Flowable
Converts aFuture, operating on a specifiedScheduler, into a Publisher.
fromFuture(Future<? extends T>) - Static method in class io.reactivex.Maybe
Converts aFuture 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 aFuture into a Maybe, with a timeout on the Future.
fromFuture(Future<? extends T>) - Static method in class io.reactivex.Observable
Converts aFuture into an ObservableSource.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class io.reactivex.Observable
Converts aFuture into an ObservableSource, with a timeout on the Future.
fromFuture(Future<? extends T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Observable
Converts aFuture into an ObservableSource, with a timeout on the Future.
fromFuture(Future<? extends T>, Scheduler) - Static method in class io.reactivex.Observable
Converts aFuture, operating on a specifiedScheduler, into an ObservableSource.
fromFuture(Future<? extends T>) - Static method in class io.reactivex.Single
Converts aFuture into aSingle.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class io.reactivex.Single
Converts aFuture into aSingle, with a timeout on the Future.
fromFuture(Future<? extends T>, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Single
Converts aFuture into aSingle, with a timeout on the Future.
fromFuture(Future<? extends T>, Scheduler) - Static method in class io.reactivex.Single
Converts aFuture, operating on a specifiedScheduler, into aSingle.
fromIterable(Iterable<? extends T>) - Static method in class io.reactivex.Flowable
Converts anIterable sequence into a Publisher that emits the items in the sequence.
fromIterable(Iterable<? extends T>) - Static method in class io.reactivex.Observable
Converts anIterable sequence into an ObservableSource that emits the items in the sequence.
fromMaybe(MaybeSource<T>) - Static method in class io.reactivex.Completable
Returns a Completable instance that when subscribed to, subscribes to theMaybe instance and emits a completion event if the maybe emitsonSuccess/onComplete or forwards anyonError events.
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 inio.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 inio.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function4<T1,T2,T3,T4,R> - Interface inio.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function5<T1,T2,T3,T4,T5,R> - Interface inio.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.
Function6<T1,T2,T3,T4,T5,T6,R> - Interface inio.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 inio.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 inio.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 inio.reactivex.functions
A functional interface (callback) that computes a value based on multiple input values.

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.
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.
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 theCompositeException.
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 thisGroupedFlowable.
getKey() - Method in class io.reactivex.observables.GroupedObservable
Returns the key that identifies the group of items emitted by thisGroupedObservable.
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.
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() - 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 ofAsyncProcessor.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 ofAsyncProcessor.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 ofBehaviorProcessor.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 ofBehaviorProcessor.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 ofAsyncSubject.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 ofAsyncSubject.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 ofBehaviorSubject.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 ofBehaviorSubject.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 aPublisher according to a specified criterion, and emits these grouped items asGroupedFlowables.
groupBy(Function<? super T, ? extends K>, boolean) - Method in class io.reactivex.Flowable
Groups the items emitted by aPublisher according to a specified criterion, and emits these grouped items asGroupedFlowables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.Flowable
Groups the items emitted by aPublisher according to a specified criterion, and emits these grouped items asGroupedFlowables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean) - Method in class io.reactivex.Flowable
Groups the items emitted by aPublisher according to a specified criterion, and emits these grouped items asGroupedFlowables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean, int) - Method in class io.reactivex.Flowable
Groups the items emitted by aPublisher according to a specified criterion, and emits these grouped items asGroupedFlowables.
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 aPublisher according to a specified criterion, and emits these grouped items asGroupedFlowables.
groupBy(Function<? super T, ? extends K>) - Method in class io.reactivex.Observable
Groups the items emitted by anObservableSource according to a specified criterion, and emits these grouped items asGroupedObservables.
groupBy(Function<? super T, ? extends K>, boolean) - Method in class io.reactivex.Observable
Groups the items emitted by anObservableSource according to a specified criterion, and emits these grouped items asGroupedObservables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.Observable
Groups the items emitted by anObservableSource according to a specified criterion, and emits these grouped items asGroupedObservables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean) - Method in class io.reactivex.Observable
Groups the items emitted by anObservableSource according to a specified criterion, and emits these grouped items asGroupedObservables.
groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean, int) - Method in class io.reactivex.Observable
Groups the items emitted by anObservableSource according to a specified criterion, and emits these grouped items asGroupedObservables.
GroupedFlowable<K,T> - Class inio.reactivex.flowables
AFlowable that has been grouped by key, the value of which can be obtained withGroupedFlowable.getKey().
GroupedFlowable(K) - Constructor for class io.reactivex.flowables.GroupedFlowable
Constructs a GroupedFlowable with the given key.
GroupedObservable<K,T> - Class inio.reactivex.observables
AnObservable that has been grouped by key, the value of which can be obtained withgetKey().
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

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 interface io.reactivex.observers.LambdaConsumerIntrospection
Returns true or false if a custom onError consumer has been provided.
hashCode() - Method in class io.reactivex.Notification
 
hashCode() - Method in class io.reactivex.schedulers.Timed
 
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
 
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.
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 viaonSubscribe().

I

ignoreElement() - Method in class io.reactivex.Maybe
Ignores the item emitted by the source Maybe and only callsonComplete oronError.
ignoreElement() - Method in class io.reactivex.Single
Returns aCompletable that ignores the success value of thisSingle and callsonComplete instead on the returnedCompletable.
ignoreElements() - Method in class io.reactivex.Flowable
Ignores all items emitted by the source Publisher and only callsonComplete oronError.
ignoreElements() - Method in class io.reactivex.Observable
Ignores all items emitted by the source ObservableSource and only callsonComplete oronError.
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.
interval(long, long, TimeUnit) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits a0L after theinitialDelay and ever-increasing numbers after eachperiod of time thereafter.
interval(long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits a0L after theinitialDelay and ever-increasing numbers after eachperiod of time thereafter, on a specifiedScheduler.
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 a0L after theinitialDelay and ever increasing numbers after eachperiod of time thereafter.
interval(long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.Observable
Returns an Observable that emits a0L after theinitialDelay and ever increasing numbers after eachperiod of time thereafter, on a specifiedScheduler.
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 inio.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'sI/O scheduler or takes timing information from it.
io() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, sharedScheduler instance intended for IO-bound work.
io.reactivex - package io.reactivex
Base reactive classes:Flowable,Observable,Single,Maybe andCompletable; 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 andGroupedFlowable.
io.reactivex.functions - package io.reactivex.functions
Functional interfaces of functions and actions of arity 0 to 9 and related utility classes.
io.reactivex.observables - package io.reactivex.observables
Classes supporting the Observable base reactive class:ConnectableObservable andGroupedObservable.
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 theTestObserver that allows unit testingObservable-,Single-,Maybe- andCompletable-based flows.
io.reactivex.parallel - package io.reactivex.parallel
Contains the base typeParallelFlowable, a sub-DSL for working withFlowable sequences in parallel.
io.reactivex.plugins - package io.reactivex.plugins
Contains the central plugin handlerRxJavaPlugins class to hook into the lifecycle of the base reactive types and schedulers.
io.reactivex.processors - package io.reactivex.processors
Classes representing so-called hot backpressure-aware sources, akaprocessors, that implement theFlowableProcessor class, the Reactive StreamsProcessor interface to allow forms of multicasting events to one or more subscribers as well as consuming another Reactive StreamsPublisher.
io.reactivex.schedulers - package io.reactivex.schedulers
Contains notably the factory class ofSchedulers providing methods for retrieving the standard scheduler instances, theTestScheduler for testing flows with scheduling in a controlled manner and the classTimed that can hold a value and a timestamp associated with it.
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 theTestSubscriber that allows unit testingFlowable-based flows.
isCancelled() - Method in interface io.reactivex.FlowableEmitter
Returns true if the downstream cancelled the sequence or the emitter was terminated viaEmitter.onError(Throwable),Emitter.onComplete() or a successfulFlowableEmitter.tryOnError(Throwable).
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.
isDisposed() - Method in interface io.reactivex.CompletableEmitter
Returns true if the downstream disposed the sequence or the emitter was terminated viaCompletableEmitter.onError(Throwable),CompletableEmitter.onComplete() or a successfulCompletableEmitter.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 interface io.reactivex.MaybeEmitter
Returns true if the downstream disposed the sequence or the emitter was terminated viaMaybeEmitter.onSuccess(Object),MaybeEmitter.onError(Throwable),MaybeEmitter.onComplete() or a successfulMaybeEmitter.tryOnError(Throwable).
isDisposed() - Method in interface io.reactivex.ObservableEmitter
Returns true if the downstream disposed the sequence or the emitter was terminated viaEmitter.onError(Throwable),Emitter.onComplete() or a successfulObservableEmitter.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 viaSingleEmitter.onSuccess(Object),SingleEmitter.onError(Throwable), or a successfulSingleEmitter.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
 
isEmpty() - Method in class io.reactivex.Flowable
Returns a Single that emitstrue if the source Publisher is empty, otherwisefalse.
isEmpty() - Method in class io.reactivex.Maybe
Returns a Single that emitstrue if the source Maybe is empty, otherwisefalse.
isEmpty() - Method in class io.reactivex.Observable
Returns a Single that emitstrue if the source ObservableSource is empty, otherwisefalse.
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.
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 andNotification.getError() returns the contained Throwable.
isOnNext() - Method in class io.reactivex.Notification
Returns true if this notification is an onNext signal andNotification.getValue() returns the contained value.
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
Returns true if an await timed out.

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 aMaybe 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 aSingle that emits a specified item.

L

LambdaConsumerIntrospection - Interface inio.reactivex.observers
An interface that indicates that the implementing type is composed of individual components and exposes information about their behavior.
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.
lastOrError() - Method in class io.reactivex.Flowable
Returns a Single that emits only the last item emitted by this Flowable or signals aNoSuchElementException 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 aNoSuchElementException 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.
lift(CompletableOperator) - Method in class io.reactivex.Completable
This method requires advanced knowledge about building operators, please consider other standard composition methods first; Returns aCompletable which, when subscribed to, invokes theapply(CompletableObserver) method of the providedCompletableOperator for each individual downstreamCompletable and allows the insertion of a custom operator by accessing the downstream'sCompletableObserver during this subscription phase and providing a newCompletableObserver, 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 aFlowable which, when subscribed to, invokes theapply(Subscriber) method of the providedFlowableOperator for each individual downstreamSubscriber and allows the insertion of a custom operator by accessing the downstream'sSubscriber during this subscription phase and providing a newSubscriber, 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 aMaybe which, when subscribed to, invokes theapply(MaybeObserver) method of the providedMaybeOperator for each individual downstreamMaybe and allows the insertion of a custom operator by accessing the downstream'sMaybeObserver during this subscription phase and providing a newMaybeObserver, 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 anObservable which, when subscribed to, invokes theapply(Observer) method of the providedObservableOperator for each individual downstreamObserver and allows the insertion of a custom operator by accessing the downstream'sObserver during this subscription phase and providing a newObserver, 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 aSingle which, when subscribed to, invokes theapply(SingleObserver) method of the providedSingleOperator for each individual downstreamSingle and allows the insertion of a custom operator by accessing the downstream'sSingleObserver during this subscription phase and providing a newSingleObserver, 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.
lockdown() - Static method in class io.reactivex.plugins.RxJavaPlugins
Prevents changing the plugins from then on.
LongConsumer - Interface inio.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 givenParallelFailureHandling 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.Completable
Maps the signal types of this Completable into aNotification of the same kind and emits it as a single success value to downstream.
materialize() - Method in class io.reactivex.Flowable
Returns a Flowable that represents all of the emissionsand notifications from the source Publisher into emissions marked with their original types withinNotification objects.
materialize() - Method in class io.reactivex.Maybe
Maps the signal types of this Maybe into aNotification of the same kind and emits it as a single success value to downstream.
materialize() - Method in class io.reactivex.Observable
Returns an Observable that represents all of the emissionsand notifications from the source ObservableSource into emissions marked with their original types withinNotification objects.
materialize() - Method in class io.reactivex.Single
Maps the signal types of this Single into aNotification of the same kind and emits it as a single success value to downstream.
Maybe<T> - Class inio.reactivex
TheMaybe class represents a deferred computation and emission of a single value, no value at all or an exception.
Maybe() - Constructor for class io.reactivex.Maybe
 
MaybeConverter<T,R> - Interface inio.reactivex
Convenience interface and callback used by theMaybe.as(io.reactivex.MaybeConverter<T, ? extends R>) operator to turn a Maybe into another value fluently.
MaybeEmitter<T> - Interface inio.reactivex
Abstraction over an RxJavaMaybeObserver that allows associating a resource with it.
MaybeObserver<T> - Interface inio.reactivex
Provides a mechanism for receiving push-based notification of a single value, an error or completion without any value.
MaybeOnSubscribe<T> - Interface inio.reactivex
A functional interface that has asubscribe() method that receives an instance of aMaybeEmitter instance that allows pushing an event in a cancellation-safe manner.
MaybeOperator<Downstream,Upstream> - Interface inio.reactivex
Interface to map/wrap a downstream observer to an upstream observer.
MaybeSource<T> - Interface inio.reactivex
Represents a basicMaybe source base interface, consumable via anMaybeObserver.
MaybeSubject<T> - Class inio.reactivex.subjects
Represents a hot Maybe-like source and consumer of events similar to Subjects.
MaybeTransformer<Upstream,Downstream> - Interface inio.reactivex
Interface to compose Maybes.
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 aMaybeSource that emits aMaybeSource into a singleMaybeSource that emits the item emitted by the nestedMaybeSource, 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 aSingle that emits aSingle into a singleSingle that emits the item emitted by the nestedSingle, 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.
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 inio.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.
MulticastProcessor<T> - Class inio.reactivex.processors
AFlowableProcessor implementation that coordinates downstream requests through a front-buffer and stable-prefetching, optionally canceling the upstream if all subscribers have cancelled.

N

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 aSubscriber.
never() - Static method in class io.reactivex.Maybe
Returns a Maybe that never sends any items or notifications to aMaybeObserver.
never() - Static method in class io.reactivex.Observable
Returns an Observable that never sends any items or notifications to anObserver.
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'snew thread scheduler or takes timing information from it.
newThread() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, sharedScheduler instance that creates a newThread for each unit of work.
NONE - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
A special value indicating the operator/class doesn't use schedulers.
NonNull - Annotation Type inio.reactivex.annotations
Indicates that a field/parameter/variable/return type is never null.
Notification<T> - Class inio.reactivex
Represents the reactive signal types: onNext, onError and onComplete and holds their parameter values (a value, a Throwable, nothing).
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 inio.reactivex.annotations
Indicates that a field/parameter/variable/return type may be null.

O

Observable<T> - Class inio.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
 
ObservableConverter<T,R> - Interface inio.reactivex
Convenience interface and callback used by theObservable.as(io.reactivex.ObservableConverter<T, ? extends R>) operator to turn an Observable into another value fluently.
ObservableEmitter<T> - Interface inio.reactivex
Abstraction over an RxJavaObserver that allows associating a resource with it.
ObservableOnSubscribe<T> - Interface inio.reactivex
A functional interface that has asubscribe() method that receives an instance of anObservableEmitter instance that allows pushing events in a cancellation-safe manner.
ObservableOperator<Downstream,Upstream> - Interface inio.reactivex
Interface to map/wrap a downstream observer to an upstream observer.
ObservableSource<T> - Interface inio.reactivex
Represents a basic, non-backpressuredObservable source base interface, consumable via anObserver.
ObservableTransformer<Upstream,Downstream> - Interface inio.reactivex
Interface to compose Observables.
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 specifiedScheduler, asynchronously with a bounded buffer ofFlowable.bufferSize() slots.
observeOn(Scheduler, boolean) - Method in class io.reactivex.Flowable
Modifies a Publisher to perform its emissions and notifications on a specifiedScheduler, 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 specifiedScheduler, asynchronously with a bounded buffer of configurable size and optionally delays onError notifications.
observeOn(Scheduler) - Method in class io.reactivex.Maybe
Wraps a Maybe to emit its item (or notify of its error) on a specifiedScheduler, asynchronously.
observeOn(Scheduler) - Method in class io.reactivex.Observable
Modifies an ObservableSource to perform its emissions and notifications on a specifiedScheduler, asynchronously with an unbounded buffer withFlowable.bufferSize() "island size".
observeOn(Scheduler, boolean) - Method in class io.reactivex.Observable
Modifies an ObservableSource to perform its emissions and notifications on a specifiedScheduler, asynchronously with an unbounded buffer withFlowable.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 specifiedScheduler, 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 specifiedScheduler, asynchronously.
Observer<T> - Interface inio.reactivex
Provides a mechanism for receiving push-based notifications.
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.
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 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 theObservable 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.
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 interface io.reactivex.MaybeEmitter
Signal an exception.
onError(Throwable) - Method in interface io.reactivex.MaybeObserver
Notifies the MaybeObserver that theMaybe has experienced an error condition.
onError(Throwable) - Method in interface io.reactivex.Observer
Notifies the Observer that theObservable 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 theSingle 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 inio.reactivex.exceptions
Represents an exception used to signal to theRxJavaPlugins.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 theThrowable with a custom message and wraps it before it is signalled to theRxJavaPlugins.onError() handler asOnErrorNotImplementedException.
OnErrorNotImplementedException(Throwable) - Constructor for exception io.reactivex.exceptions.OnErrorNotImplementedException
Wraps theThrowable before it is signalled to theRxJavaPlugins.onError() handler asOnErrorNotImplementedException.
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 invokingonError 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 invokingonError if it encounters an error.
onErrorResumeNext(MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Instructs a Maybe to pass control to anotherMaybeSource rather than invokingonError 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 invokingonError 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 invokingonError 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 invokingonError 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 invokingSingleObserver.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 invokingSingleObserver.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 invokingonError 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 invokingonError 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 invokingonError 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 invokingonError 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 invokingonError 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 invokingonError 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 invokingonError 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 invokingonError if it encounters anException.
onExceptionResumeNext(MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
Instructs a Maybe to pass control to another MaybeSource rather than invokingonError if it encounters anException.
onExceptionResumeNext(ObservableSource<? extends T>) - Method in class io.reactivex.Observable
Instructs an ObservableSource to pass control to another ObservableSource rather than invokingonError if it encounters anException.
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 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 inSubscriber.onNext(Object) is established before callingSubscription.request(long).
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 withinonSubscribe(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 withinObserver.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 withinonSubscribe(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 interface io.reactivex.MaybeEmitter
Signal a success value.
onSuccess(T) - Method in interface io.reactivex.MaybeObserver
Notifies the MaybeObserver with one item and that theMaybe 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 theSingle 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().

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.
ParallelFailureHandling - Enum inio.reactivex.parallel
Enumerations for handling failure within a parallel operator.
ParallelFlowable<T> - Class inio.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 inio.reactivex.parallel
Convenience interface and callback used by theParallelFlowable.as(io.reactivex.parallel.ParallelFlowableConverter<T, R>) operator to turn a ParallelFlowable into another value fluently.
parallelism() - Method in class io.reactivex.parallel.ParallelFlowable
Returns the number of expected parallel Subscribers.
ParallelTransformer<Upstream,Downstream> - Interface inio.reactivex.parallel
Interface to compose ParallelFlowable.
Predicate<T> - Interface inio.reactivex.functions
A functional interface (callback) that returns true or false for the given input value.
printStackTrace() - Method in exception io.reactivex.exceptions.CompositeException
All of the followingprintStackTrace functionality is derived from JDKThrowableprintStackTrace.
printStackTrace(PrintStream) - Method in exception io.reactivex.exceptions.CompositeException
 
printStackTrace(PrintWriter) - Method in exception io.reactivex.exceptions.CompositeException
 
propagate(Throwable) - Static method in class io.reactivex.exceptions.Exceptions
Convenience method to throw aRuntimeException andError directly or wrap any other exception type into aRuntimeException.
ProtocolViolationException - Exception inio.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 aConnectableFlowable, which is a variety of Publisher that waits until itsconnect method is called before it begins emitting items to thoseSubscribers 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 aConnectableFlowable 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 aConnectableFlowable that shares a single subscription to the underlying sequence.
publish(int) - Method in class io.reactivex.Flowable
Returns aConnectableFlowable, which is a variety of Publisher that waits until itsconnect method is called before it begins emitting items to thoseSubscribers that have subscribed to it.
publish() - Method in class io.reactivex.Observable
Returns aConnectableObservable, which is a variety of ObservableSource that waits until itsconnect method is called before it begins emitting items to thoseObservers 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 aConnectableObservable that shares a single subscription to the underlying sequence.
PublishProcessor<T> - Class inio.reactivex.processors
Processor that multicasts all subsequently observed items to its currentSubscribers.
PublishSubject<T> - Class inio.reactivex.subjects
A Subject that emits (multicasts) items to currently subscribedObservers and terminal events to current or lateObservers.

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
Requestsn initially from the upstream and then 75% ofn subsequently after 75% ofn 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 aFlowable that stays connected to thisConnectableFlowable as long as there is at least one subscription to thisConnectableFlowable.
refCount(int) - Method in class io.reactivex.flowables.ConnectableFlowable
Connects to the upstreamConnectableFlowable 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 upstreamConnectableFlowable 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 upstreamConnectableFlowable 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 upstreamConnectableFlowable 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 upstreamConnectableFlowable 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 anObservable that stays connected to thisConnectableObservable as long as there is at least one subscription to thisConnectableObservable.
refCount(int) - Method in class io.reactivex.observables.ConnectableObservable
Connects to the upstreamConnectableObservable 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 upstreamConnectableObservable 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 upstreamConnectableObservable 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 upstreamConnectableObservable 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 upstreamConnectableObservable 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.
repeat() - Method in class io.reactivex.Completable
Returns a Completable that repeatedly subscribes to this Completable until disposed.
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 mostcount 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 mostcount 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 mostcount 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 anonComplete.
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 anonComplete.
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 anonComplete.
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.
replay() - Method in class io.reactivex.Flowable
Returns aConnectableFlowable that shares a single subscription to the underlying Publisher that will replay all of its items and notifications to any futureSubscriber.
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 aConnectableFlowable 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 aConnectableFlowable that shares a single subscription to the source Publisher, replayingbufferSize 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 aConnectableFlowable that shares a single subscription to the source Publisher, replaying no more thanbufferSize 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 aConnectableFlowable that shares a single subscription to the source Publisher, replaying no more thanbufferSize 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 aConnectableFlowable that shares a single subscription to the source Publisher, replaying a maximum ofbufferSize 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 aConnectableFlowable 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 aConnectableFlowable 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 aConnectableFlowable that shares a single subscription to the source Publisher.
replay(int) - Method in class io.reactivex.Flowable
Returns aConnectableFlowable that shares a single subscription to the source Publisher that replays at mostbufferSize items emitted by that Publisher.
replay(int, long, TimeUnit) - Method in class io.reactivex.Flowable
Returns aConnectableFlowable that shares a single subscription to the source Publisher and replays at mostbufferSize items that were emitted during a specified time window.
replay(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns aConnectableFlowable that shares a single subscription to the source Publisher and that replays a maximum ofbufferSize items that are emitted within a specified time window.
replay(int, Scheduler) - Method in class io.reactivex.Flowable
Returns aConnectableFlowable that shares a single subscription to the source Publisher and replays at mostbufferSize items emitted by that Publisher.
replay(long, TimeUnit) - Method in class io.reactivex.Flowable
Returns aConnectableFlowable 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 aConnectableFlowable 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 aConnectableFlowable that shares a single subscription to the source Publisher that will replay all of its items and notifications to any futureSubscriber on the givenScheduler.
replay() - Method in class io.reactivex.Observable
Returns aConnectableObservable that shares a single subscription to the underlying ObservableSource that will replay all of its items and notifications to any futureObserver.
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 aConnectableObservable 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 aConnectableObservable that shares a single subscription to the source ObservableSource, replayingbufferSize 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 aConnectableObservable that shares a single subscription to the source ObservableSource, replaying no more thanbufferSize 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 aConnectableObservable that shares a single subscription to the source ObservableSource, replaying no more thanbufferSize 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 aConnectableObservable that shares a single subscription to the source ObservableSource, replaying a maximum ofbufferSize 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 aConnectableObservable 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 aConnectableObservable 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 aConnectableObservable that shares a single subscription to the source ObservableSource.
replay(int) - Method in class io.reactivex.Observable
Returns aConnectableObservable that shares a single subscription to the source ObservableSource that replays at mostbufferSize items emitted by that ObservableSource.
replay(int, long, TimeUnit) - Method in class io.reactivex.Observable
Returns aConnectableObservable that shares a single subscription to the source ObservableSource and replays at mostbufferSize items that were emitted during a specified time window.
replay(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns aConnectableObservable that shares a single subscription to the source ObservableSource and that replays a maximum ofbufferSize items that are emitted within a specified time window.
replay(int, Scheduler) - Method in class io.reactivex.Observable
Returns aConnectableObservable that shares a single subscription to the source ObservableSource and replays at mostbufferSize items emitted by that ObservableSource.
replay(long, TimeUnit) - Method in class io.reactivex.Observable
Returns aConnectableObservable 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 aConnectableObservable 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 aConnectableObservable that shares a single subscription to the source ObservableSource that will replay all of its items and notifications to any futureObserver on the givenScheduler.
ReplayProcessor<T> - Class inio.reactivex.processors
Replays events to Subscribers.
ReplaySubject<T> - Class inio.reactivex.subjects
Replays events (in a configurable bounded or unbounded manner) to current and lateObservers.
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
 
requested() - Method in interface io.reactivex.FlowableEmitter
The current outstanding request amount.
requestMore(long) - Method in class io.reactivex.subscribers.TestSubscriber
CallsTestSubscriber.request(long) and returns this.
reset() - Static method in class io.reactivex.plugins.RxJavaPlugins
Removes all handlers and resets to default behavior.
ResourceCompletableObserver - Class inio.reactivex.observers
An abstractCompletableObserver that allows asynchronous cancellation of its subscription and associated resources.
ResourceCompletableObserver() - Constructor for class io.reactivex.observers.ResourceCompletableObserver
 
ResourceMaybeObserver<T> - Class inio.reactivex.observers
An abstractMaybeObserver that allows asynchronous cancellation of its subscription and associated resources.
ResourceMaybeObserver() - Constructor for class io.reactivex.observers.ResourceMaybeObserver
 
ResourceObserver<T> - Class inio.reactivex.observers
An abstractObserver that allows asynchronous cancellation of its subscription and associated resources.
ResourceObserver() - Constructor for class io.reactivex.observers.ResourceObserver
 
ResourceSingleObserver<T> - Class inio.reactivex.observers
An abstractSingleObserver that allows asynchronous cancellation of its subscription and the associated resources.
ResourceSingleObserver() - Constructor for class io.reactivex.observers.ResourceSingleObserver
 
ResourceSubscriber<T> - Class inio.reactivex.subscribers
An abstract Subscriber that allows asynchronous cancellation of its subscription and associated resources.
ResourceSubscriber() - Constructor for class io.reactivex.subscribers.ResourceSubscriber
 
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 callsonError (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 callsonError 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 callsonError 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 callsonError (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 callsonError 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 callsonError 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 callsonError (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 callsonError 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 callsonError 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 anonError.
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 anonError.
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 anonError.
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.
run() - Method in interface io.reactivex.functions.Action
Runs the action and optionally throws a checked exception.
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 inio.reactivex.plugins
Utility class to inject handlers to certain standard RxJava operations.

S

SafeObserver<T> - Class inio.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 inio.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 specifiedsampler Publisher emits an item or completes, emits the most recently emitted item (if any) emitted by the source Publisher since the previous emission from thesampler Publisher.
sample(Publisher<U>, boolean) - Method in class io.reactivex.Flowable
Returns a Flowable that, when the specifiedsampler Publisher emits an item or completes, emits the most recently emitted item (if any) emitted by the source Publisher since the previous emission from thesampler 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 specifiedsampler ObservableSource emits an item or completes, emits the most recently emitted item (if any) emitted by the source ObservableSource since the previous emission from thesampler ObservableSource.
sample(ObservableSource<U>, boolean) - Method in class io.reactivex.Observable
Returns an Observable that, when the specifiedsampler ObservableSource emits an item or completes, emits the most recently emitted item (if any) emitted by the source ObservableSource since the previous emission from thesampler ObservableSource and optionally emit the very last upstream item when the upstream or other ObservableSource complete.
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.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.
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.
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.Scheduler
Schedules a periodic execution of the given task with the given initial time delay and repeat period.
Scheduler - Class inio.reactivex
AScheduler is an object that specifies an API for scheduling units of work provided in the form ofRunnables 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 inio.reactivex
Represents an isolated, sequential worker of a parent Scheduler for executingRunnable tasks on an underlying task-execution scheme (such as custom Threads, event loop,Executor or Actor system).
SchedulerRunnableIntrospection - Interface inio.reactivex.schedulers
Interface to indicate the implementor class wraps aRunnable that can be accessed viaSchedulerRunnableIntrospection.getWrappedRunnable().
Schedulers - Class inio.reactivex.schedulers
Static factory methods for returning standard Scheduler instances.
SchedulerSupport - Annotation Type inio.reactivex.annotations
Indicates what kind of scheduler the class or method uses.
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.
SerialDisposable - Class inio.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 obeythe 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 obeythe 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 inio.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 inio.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.
setCancellable(Cancellable) - Method in interface io.reactivex.CompletableEmitter
Sets a Cancellable on this emitter; any previousDisposable orCancellable will be disposed/cancelled.
setCancellable(Cancellable) - Method in interface io.reactivex.FlowableEmitter
Sets a Cancellable on this emitter; any previousDisposable orCancellable will be disposed/cancelled.
setCancellable(Cancellable) - Method in interface io.reactivex.MaybeEmitter
Sets a Cancellable on this emitter; any previousDisposable orCancellable will be disposed/cancelled.
setCancellable(Cancellable) - Method in interface io.reactivex.ObservableEmitter
Sets a Cancellable on this emitter; any previousDisposable orCancellable will be disposed/cancelled.
setCancellable(Cancellable) - Method in interface io.reactivex.SingleEmitter
Sets a Cancellable on this emitter; any previousDisposable orCancellable will be disposed/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 previousDisposable orCancellable will be disposed/cancelled.
setDisposable(Disposable) - Method in interface io.reactivex.FlowableEmitter
Sets a Disposable on this emitter; any previousDisposable orCancellable will be disposed/cancelled.
setDisposable(Disposable) - Method in interface io.reactivex.MaybeEmitter
Sets a Disposable on this emitter; any previousDisposable orCancellable will be disposed/cancelled.
setDisposable(Disposable) - Method in interface io.reactivex.ObservableEmitter
Sets a Disposable on this emitter; any previousDisposable orCancellable will be disposed/cancelled.
setDisposable(Disposable) - Method in interface io.reactivex.SingleEmitter
Sets a Disposable on this emitter; any previous Disposable or Cancellable will be disposed/cancelled.
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.
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.
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.
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.
share() - Method in class io.reactivex.Flowable
Returns a newPublisher that multicasts (and shares a single subscription to) the originalPublisher.
share() - Method in class io.reactivex.Observable
Returns a newObservableSource that multicasts (and shares a single subscription to) the originalObservableSource.
shutdown() - Method in class io.reactivex.Scheduler
Instructs the Scheduler instance to stop threads, stop accepting tasks on any outstandingScheduler.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.
SINGLE - Static variable in annotation type io.reactivex.annotations.SchedulerSupport
The operator/class runs on RxJava'ssingle 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-backedScheduler instance for work requiring strongly-sequential execution on the same background thread.
Single<T> - Class inio.reactivex
TheSingle class implements the Reactive Pattern for a single value response.
Single() - Constructor for class io.reactivex.Single
 
SingleConverter<T,R> - Interface inio.reactivex
Convenience interface and callback used by theSingle.as(io.reactivex.SingleConverter<T, ? extends R>) operator to turn a Single into another value fluently.
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 anIllegalArgumentException 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 anIllegalArgumentException if this Observable emits more than one item.
SingleEmitter<T> - Interface inio.reactivex
Abstraction over an RxJavaSingleObserver that allows associating a resource with it.
SingleObserver<T> - Interface inio.reactivex
Provides a mechanism for receiving push-based notification of a single value or an error.
SingleOnSubscribe<T> - Interface inio.reactivex
A functional interface that has asubscribe() method that receives an instance of aSingleEmitter instance that allows pushing an event in a cancellation-safe manner.
SingleOperator<Downstream,Upstream> - Interface inio.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 aNoSuchElementException will be signaled and if this Flowable emits more than one item, anIllegalArgumentException 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 aNoSuchElementException orIllegalArgumentException will be signalled respectively.
SingleSource<T> - Interface inio.reactivex
Represents a basicSingle source base interface, consumable via anSingleObserver.
SingleSubject<T> - Class inio.reactivex.subjects
Represents a hot Single-like source and consumer of events similar to Subjects.
SingleTransformer<Upstream,Downstream> - Interface inio.reactivex
Interface to compose Singles.
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.
skip(long) - Method in class io.reactivex.Flowable
Returns a Flowable that skips the firstcount 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 specifiedScheduler elapses.
skip(long) - Method in class io.reactivex.Observable
Returns an Observable that skips the firstcount 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 specifiedScheduler 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.
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 specifiedIterable 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 specifiedPublisher 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 specifiedIterable 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 specifiedObservableSource 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.
Subject<T> - Class inio.reactivex.subjects
Represents anObserver and anObservable at the same time, allowing multicasting events from a single source to multiple childObservers.
Subject() - Constructor for class io.reactivex.subjects.Subject
 
subscribe() - Method in class io.reactivex.Completable
Subscribes to this CompletableConsumable and returns a Disposable which can be used to dispose 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 ignoresonNext andonComplete 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() - Method in class io.reactivex.Maybe
Subscribes to a Maybe and ignoresonSuccess andonComplete 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 ignoresonNext andonComplete 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 incomingCompletableObservers 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 incomingSubscribers.
subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.Maybe
Implement this method in subclasses to handle the incomingMaybeObservers.
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 incomingObservers.
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 incomingSingleObservers.
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 specifiedScheduler.
subscribeOn(Scheduler, boolean) - Method in class io.reactivex.Flowable
Asynchronously subscribes Subscribers to this Publisher on the specifiedScheduler optionally reroutes requests from other threads to the sameScheduler thread.
subscribeOn(Scheduler) - Method in class io.reactivex.Maybe
Asynchronously subscribes subscribers to this Maybe on the specifiedScheduler.
subscribeOn(Scheduler) - Method in class io.reactivex.Observable
Asynchronously subscribes Observers to this ObservableSource on the specifiedScheduler.
subscribeOn(Scheduler) - Method in class io.reactivex.Single
Asynchronously subscribes subscribers to this Single on the specifiedScheduler.
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.
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 intoCompletableSources, subscribes to the newer one while disposing the subscription to the previousCompletableSource, thus keeping at most one activeCompletableSource running.
switchMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Observable
Maps the upstream values intoCompletableSources, subscribes to the newer one while disposing the subscription to the previousCompletableSource, thus keeping at most one activeCompletableSource running.
switchMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.Flowable
Maps the upstream values intoCompletableSources, subscribes to the newer one while disposing the subscription to the previousCompletableSource, thus keeping at most one activeCompletableSource 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 intoCompletableSources, subscribes to the newer one while disposing the subscription to the previousCompletableSource, thus keeping at most one activeCompletableSource 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 intoMaybeSources 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 thisFlowable or any of the active innerMaybeSources fail.
switchMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items intoMaybeSources 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 thisObservable or any of the active innerMaybeSources fail.
switchMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items intoMaybeSources 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 thisFlowable or the innerMaybeSources until all terminate.
switchMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.Observable
Maps the upstream items intoMaybeSources 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 thisObservable or the innerMaybeSources until all terminate.
switchMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.Flowable
Maps the upstream items intoSingleSources 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 thisFlowable or any of the active innerSingleSources 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 intoSingleSources 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 thisFlowable or the innerSingleSources 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.

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 firstcount 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 firstcount 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 lastcount 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 lastcount 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(CompletableSource) - Method in class io.reactivex.Completable
Terminates the downstream if this or the otherCompletable terminates (wins the termination race) while disposing the connection to the losing source.
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.
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() - 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 inio.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 inio.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 inio.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 upstreamFlowable 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 upstreamFlowable 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 upstreamFlowable 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 upstreamFlowable 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 upstreamObservable 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 upstreamObservable 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 upstreamObservable 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 upstreamObservable 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 particularThrowable only if it belongs to a set of "fatal" error varieties.
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 inio.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 aTimeoutException 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 aTimeoutException 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 currentMaybe didn't signal an event before thetimeoutIndicatorMaybeSource signals, aTimeoutException is signaled instead.
timeout(MaybeSource<U>, MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
If the currentMaybe didn't signal an event before thetimeoutIndicatorMaybeSource signals, the currentMaybe is disposed and thefallbackMaybeSource subscribed to as a continuation.
timeout(Publisher<U>) - Method in class io.reactivex.Maybe
If the currentMaybe source didn't signal an event before thetimeoutIndicatorPublisher signals, aTimeoutException is signaled instead.
timeout(Publisher<U>, MaybeSource<? extends T>) - Method in class io.reactivex.Maybe
If the currentMaybe didn't signal an event before thetimeoutIndicatorPublisher signals, the currentMaybe is disposed and thefallbackMaybeSource 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 aTimeoutException 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 aTimeoutException 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 disposed 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 disposed 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 emits0L after a specified delay, and then completes.
timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Flowable
Returns a Flowable that emits0L 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 emits0L after a specified delay.
timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Maybe
Returns a Maybe that emits0L after a specified delay on a specified Scheduler.
timer(long, TimeUnit) - Static method in class io.reactivex.Observable
Returns an Observable that emits0L after a specified delay, and then completes.
timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.Observable
Returns an Observable that emits0L 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 aTimed object.
timestamp(Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in aTimed 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 aTimed object.
timestamp(TimeUnit, Scheduler) - Method in class io.reactivex.Flowable
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in aTimed 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 aTimed object.
timestamp(Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits each item emitted by the source ObservableSource, wrapped in aTimed 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 aTimed object.
timestamp(TimeUnit, Scheduler) - Method in class io.reactivex.Observable
Returns an Observable that emits each item emitted by the source ObservableSource, wrapped in aTimed object whose timestamps are provided by a specified Scheduler.
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.
toCompletable() - Method in class io.reactivex.Single
Deprecated.
seeSingle.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() - 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 aFlowable.
toFuture() - Method in class io.reactivex.Flowable
Returns aFuture representing the only value emitted by thisFlowable.
toFuture() - Method in class io.reactivex.Observable
Returns aFuture representing the only value emitted by thisObservable.
toFuture() - Method in class io.reactivex.Single
Returns aFuture representing the single value emitted by thisSingle.
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 specifiedkeySelector 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 specifiedkeySelector 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 specifiedmapFactory 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 specifiedkeySelector 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 specifiedkeySelector 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 specifiedmapFactory function, that contains keys and values extracted from the items emitted by the finite source ObservableSource.
toMaybe() - Method in class io.reactivex.Completable
Converts this Completable into aMaybe.
toMaybe() - Method in class io.reactivex.Single
Converts this Single into aMaybe.
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 specifiedkeySelector 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 specifiedvalueSelector function from items emitted by the finite source Publisher, keyed by a specifiedkeySelector 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 specifiedmapFactory function, that contains a custom collection of values, extracted by a specifiedvalueSelector function from items emitted by the finite source Publisher, and keyed by thekeySelector 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 specifiedmapFactory function, that contains an ArrayList of values, extracted by a specifiedvalueSelector function from items emitted by the finite source Publisher and keyed by thekeySelector 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 specifiedkeySelector 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 specifiedvalueSelector function from items emitted by the finite source ObservableSource, keyed by a specifiedkeySelector 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 specifiedmapFactory function, that contains a custom collection of values, extracted by a specifiedvalueSelector function from items emitted by the source ObservableSource, and keyed by thekeySelector 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 specifiedmapFactory function, that contains an ArrayList of values, extracted by a specifiedvalueSelector function from items emitted by the finite source ObservableSource and keyed by thekeySelector function.
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-backpressuredObservable.
toObservable() - Method in class io.reactivex.Maybe
Converts this Maybe into an Observable instance composing disposal through.
toObservable() - Method in class io.reactivex.Single
Converts this Single into anObservable.
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 disposal 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 disposal 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.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'strampoline scheduler or takes timing information from it.
trampoline() - Static method in class io.reactivex.schedulers.Schedulers
Returns a default, sharedScheduler instance whoseScheduler.Worker instances queue work and execute them in a FIFO manner on one of the participating threads.
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.
tryOnError(Throwable) - Method in interface io.reactivex.CompletableEmitter
Attempts to emit the specifiedThrowable 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 specifiedThrowable 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 specifiedThrowable 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 specifiedThrowable 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 specifiedThrowable 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.

U

UndeliverableException - Exception inio.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 inio.reactivex.processors
AFlowableProcessor variant that queues up events until a singleSubscriber subscribes to it, replays those events to it until theSubscriber catches up and then switches to relaying events live to this singleSubscriber until thisUnicastProcessor terminates or theSubscriber cancels its subscription.
UnicastSubject<T> - Class inio.reactivex.subjects
A Subject that queues up events until a singleObserver subscribes to it, replays those events to it until theObserver catches up and then switches to relaying events live to this singleObserver until thisUnicastSubject terminates or theObserver 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 callbackwithout any safeguards; you should manage the lifecycle and response to downstream disposal.
unsafeCreate(Publisher<T>) - Static method in class io.reactivex.Flowable
Create a Flowable by wrapping a Publisherwhich 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 ObservableSourcewhich has to be implemented according to the Reactive Streams based Observable specification by handling disposal 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 disposes 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 specifiedScheduler.
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 specifiedScheduler.
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.
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 setdisposeEagerly totrue 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 setdisposeEagerly totrue 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 setdisposeEagerly totrue 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(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() - 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.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, inthe order they are declared.
values() - Static method in enum io.reactivex.BackpressureOverflowStrategy
Returns an array containing the constants of this enum type, inthe order they are declared.
values() - Static method in enum io.reactivex.BackpressureStrategy
Returns an array containing the constants of this enum type, inthe order they are declared.
values() - Static method in enum io.reactivex.observers.BaseTestConsumer.TestWaitStrategy
Returns an array containing the constants of this enum type, inthe 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, inthe order they are declared.

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 theresultSelector 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 theresultSelector 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.

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 ofn items emitted, in sequence, by then 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 ofn items emitted, in sequence, by then 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(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 L M N O P R S T U V W Z 
Skip navigation links

[8]ページ先頭

©2009-2025 Movatter.jp