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(Observer<? super T>) - Method in class rx.Notification
Forwards this notification on to a specified Observer.
Action - Interface in rx.functions
All Action interfaces extend from this.
Action0 - Interface in rx.functions
A zero-argument action.
Action1<T> - Interface in rx.functions
A one-argument action.
Action2<T1,T2> - Interface in rx.functions
A two-argument action.
Action3<T1,T2,T3> - Interface in rx.functions
A three-argument action.
Action4<T1,T2,T3,T4> - Interface in rx.functions
A four-argument action.
Action5<T1,T2,T3,T4,T5> - Interface in rx.functions
A five-argument action.
Action6<T1,T2,T3,T4,T5,T6> - Interface in rx.functions
A six-argument action.
Action7<T1,T2,T3,T4,T5,T6,T7> - Interface in rx.functions
A seven-argument action.
Action8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in rx.functions
An eight-argument action.
Action9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Interface in rx.functions
A nine-argument action.
ActionN - Interface in rx.functions
A vector-argument action.
Actions - Class in rx.functions
Utility class for the Action interfaces.
add(Subscription) - Method in class rx.SingleSubscriber
Adds a Subscription to this Subscriber's list of subscriptions if this list is not marked as unsubscribed.
add(Subscription) - Method in class rx.Subscriber
Adds a Subscription to this Subscriber's list of subscriptions if this list is not marked as unsubscribed.
add(Subscription) - Method in class rx.subscriptions.CompositeSubscription
Adds a new Subscription to this CompositeSubscription if the CompositeSubscription is not yet unsubscribed.
addAll(Subscription...) - Method in class rx.subscriptions.CompositeSubscription
Adds collection of Subscription to this CompositeSubscription if the CompositeSubscription is not yet unsubscribed.
addCause(Throwable, Throwable) - Static method in class rx.exceptions.Exceptions
Adds a Throwable to a causality-chain of Throwables, as an additional cause (if it does not already appear in the chain among the causes).
addValueAsLastCause(Throwable, Object) - Static method in exception rx.exceptions.OnErrorThrowable
Adds the given item as the final cause of the given Throwable, wrapped in OnNextValue (which extends RuntimeException).
advanceTimeBy(long, TimeUnit) - Method in class rx.schedulers.TestScheduler
Moves the Scheduler's clock forward by a specified amount of time.
advanceTimeTo(long, TimeUnit) - Method in class rx.schedulers.TestScheduler
Moves the Scheduler's clock to a particular moment in time.
all(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits a Boolean that indicates whether all of the items emitted by the source Observable satisfy a condition.
amb(Completable...) - Static method in class rx.Completable
Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.
amb(Iterable<? extends Completable>) - Static method in class rx.Completable
Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.
amb(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Mirrors the one Observable in an Iterable of several Observables that first either emits an item or sends a termination notification.
amb(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Given two Observables, mirrors the one that first either emits an item or sends a termination notification.
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Given three Observables, mirrors the one that first either emits an item or sends a termination notification.
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Given four Observables, mirrors the one that first either emits an item or sends a termination notification.
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Given five Observables, mirrors the one that first either emits an item or sends a termination notification.
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Given six Observables, mirrors the one that first either emits an item or sends a termination notification.
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Given seven Observables, mirrors the one that first either emits an item or sends a termination notification.
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Given eight Observables, mirrors the one that first either emits an item or sends a termination notification.
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Given nine Observables, mirrors the one that first either emits an item or sends a termination notification.
ambWith(Completable) - Method in class rx.Completable
Returns a Completable that emits the a terminated event of either this Completable or the other Completable whichever fires first.
ambWith(Observable<? extends T>) - Method in class rx.Observable
Mirrors the Observable (current or provided) that first either emits an item or sends a termination notification.
andThen(Observable<T>) - Method in class rx.Completable
Returns an Observable which will subscribe to this Completable and once that is completed then will subscribe to the next Observable.
andThen(Single<T>) - Method in class rx.Completable
Returns a Single which will subscribe to this Completable and once that is completed then will subscribe to the next Single.
andThen(Completable) - Method in class rx.Completable
Returns a completable that first runs this Completable and then the other completable.
asObservable() - Method in class rx.Observable
Portrays a object of an Observable subclass as a simple Observable object.
AssemblyStackTraceException - Exception in rx.exceptions
A RuntimeException that is stackless but holds onto a textual stacktrace from tracking the assembly location of operators.
AssemblyStackTraceException(String) - Constructor for exception rx.exceptions.AssemblyStackTraceException
Constructs an AssemblyStackTraceException with the given message.
AssertableSubscriber<T> - Interface in rx.observers
Interface for asserting the state of a sequence under testing with a test() method of a reactive base class.
assertCompleted() - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received exaclty one onCompleted signal.
assertCompleted() - Method in class rx.observers.TestSubscriber
Asserts that there is exactly one completion event.
assertError(Class<? extends Throwable>) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received one onError signal with the given subclass of a Throwable as type.
assertError(Throwable) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received one onError signal with the object-equals of the given Throwable instance
assertError(Class<? extends Throwable>) - Method in class rx.observers.TestSubscriber
Asserts that there is exactly one error event which is a subclass of the given class.
assertError(Throwable) - Method in class rx.observers.TestSubscriber
Asserts that there is a single onError event with the exact exception.
assertFailure(Class<? extends Throwable>, T...) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received the specified items in the given order followed by an error signal of the given type (but no completion signal).
assertFailureAndMessage(Class<? extends Throwable>, String, T...) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received the specified items in the given order followed by an error signal of the given type and with the exact error message (but no completion signal).
assertNoErrors() - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer has not received any onError signal.
assertNoErrors() - Method in class rx.observers.TestSubscriber
Asserts that this Subscriber has received no onError notifications.
assertNotCompleted() - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received no onCompleted signal.
assertNotCompleted() - Method in class rx.observers.TestSubscriber
Asserts that there is no completion event.
assertNoTerminalEvent() - Method in interface rx.observers.AssertableSubscriber
Assert that no onError or onCompleted signals were received so far.
assertNoTerminalEvent() - Method in class rx.observers.TestSubscriber
Asserts that there are no onError and onCompleted events.
assertNoValues() - Method in interface rx.observers.AssertableSubscriber
Assert that no onNext signals were received so far.
assertNoValues() - Method in class rx.observers.TestSubscriber
Asserts that there are no onNext events received.
assertReceivedOnNext(List<T>) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received the given list of items as onNext signals in the same order and with the default null-safe object equals comparison.
assertReceivedOnNext(List<T>) - Method in class rx.observers.TestObserver
Deprecated.
Assert that a particular sequence of items was received in order.
assertReceivedOnNext(List<T>) - Method in class rx.observers.TestSubscriber
Asserts that a particular sequence of items was received by this Subscriber in order.
assertResult(T...) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received the specified items in the given order followed by a completion signal and no errors.
assertTerminalEvent() - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received either an onError or onCompleted signal.
assertTerminalEvent() - Method in class rx.observers.TestObserver
Deprecated.
Assert that a single terminal event occurred, either TestObserver.onCompleted() or TestObserver.onError(java.lang.Throwable).
assertTerminalEvent() - Method in class rx.observers.TestSubscriber
Asserts that a single terminal event occurred, either TestSubscriber.onCompleted() or TestSubscriber.onError(java.lang.Throwable).
assertUnsubscribed() - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer has been unsubscribed via unsubscribe() or by a wrapping SafeSubscriber.
assertUnsubscribed() - Method in class rx.observers.TestSubscriber
Asserts that this Subscriber is unsubscribed.
assertValue(T) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received exactly the given single expected value (compared via null-safe object equals).
assertValue(T) - Method in class rx.observers.TestSubscriber
Asserts that there is only a single received onNext event and that it marks the emission of a specific item.
assertValueCount(int) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received exactly the given count of onNext signals.
assertValueCount(int) - Method in class rx.observers.TestSubscriber
Asserts that the given number of onNext events are received.
assertValues(T...) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received exactly the given expected values (compared via null-safe object equals) in the given order.
assertValues(T...) - Method in class rx.observers.TestSubscriber
Asserts that the received onNext events, in order, are the specified items.
assertValuesAndClear(T, T...) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer received exactly the given values (compared via null-safe object equals) and if so, clears the internal buffer of the underlying Subscriber of these values.
assertValuesAndClear(T, T...) - Method in class rx.observers.TestSubscriber
Assert that the TestSubscriber contains the given first and optional rest values exactly and if so, clears the internal list of values.
AsyncCompletableSubscriber - Class in rx.observers
An abstract base class for CompletableSubscriber implementations that want to expose an unsubscription capability.
AsyncCompletableSubscriber() - Constructor for class rx.observers.AsyncCompletableSubscriber
 
AsyncOnSubscribe<S,T> - Class in rx.observables
A utility class to create OnSubscribe<T> functions that respond correctly to back pressure requests from subscribers.
AsyncOnSubscribe() - Constructor for class rx.observables.AsyncOnSubscribe
 
AsyncSubject<T> - Class in rx.subjects
Subject that publishes only the last item observed to each Observer once the source Observable has completed.
AsyncSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>) - Constructor for class rx.subjects.AsyncSubject
 
attachTo(Throwable) - Method in exception rx.exceptions.AssemblyStackTraceException
Finds an empty cause slot and assigns itself to it.
autoConnect() - Method in class rx.observables.ConnectableObservable
Returns an Observable that automatically connects to this ConnectableObservable when the first Subscriber subscribes.
autoConnect(int) - Method in class rx.observables.ConnectableObservable
Returns an Observable that automatically connects to this ConnectableObservable when the specified number of Subscribers subscribe to it.
autoConnect(int, Action1<? super Subscription>) - Method in class rx.observables.ConnectableObservable
Returns an Observable that automatically connects 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 rx.Completable
Subscribes to and awaits the termination of this Completable instance in a blocking manner and rethrows any exception emitted.
await(long, TimeUnit) - Method in class rx.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.
awaitTerminalEvent() - Method in interface rx.observers.AssertableSubscriber
Waits for an onError or {code onCompleted} terminal event indefinitely.
awaitTerminalEvent(long, TimeUnit) - Method in interface rx.observers.AssertableSubscriber
Waits for an onError or {code onCompleted} terminal event for the given amount of timeout.
awaitTerminalEvent() - Method in class rx.observers.TestSubscriber
Blocks until this Subscriber receives a notification that the Observable is complete (either an onCompleted or onError notification).
awaitTerminalEvent(long, TimeUnit) - Method in class rx.observers.TestSubscriber
Blocks until this Subscriber receives a notification that the Observable is complete (either an onCompleted or onError notification), or until a timeout expires.
awaitTerminalEventAndUnsubscribeOnTimeout(long, TimeUnit) - Method in interface rx.observers.AssertableSubscriber
Waits for an onError or {code onCompleted} terminal event for the given amount of timeout and unsubscribes the sequence if the timeout passed or the wait itself is interrupted.
awaitTerminalEventAndUnsubscribeOnTimeout(long, TimeUnit) - Method in class rx.observers.TestSubscriber
Blocks until this Subscriber receives a notification that the Observable is complete (either an onCompleted or onError notification), or until a timeout expires; if the Subscriber is interrupted before either of these events take place, this method unsubscribes the Subscriber from the Observable).
awaitValueCount(int, long, TimeUnit) - Method in interface rx.observers.AssertableSubscriber
Assert that this Observer receives at least the given number of onNext signals within the specified timeout period.
awaitValueCount(int, long, TimeUnit) - Method in class rx.observers.TestSubscriber
Wait until the current committed value count is less than the expected amount by sleeping 1 unit at most timeout times and return true if at least the required amount of onNext values have been received.

B

BackpressureOverflow - Class in rx
Generic strategy and default implementations to deal with backpressure buffer overflows.
BackpressureOverflow.Strategy - Interface in rx
Represents a callback called when a value is about to be dropped due to lack of downstream requests.
BehaviorSubject<T> - Class in rx.subjects
Subject that emits the most recent item it has observed and all subsequent observed items to each subscribed Observer.
BehaviorSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>) - Constructor for class rx.subjects.BehaviorSubject
 
Beta - Annotation Type in rx.annotations
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
BlockingObservable<T> - Class in rx.observables
BlockingObservable is a variety of Observable that provides blocking operators.
BlockingSingle<T> - Class in rx.singles
BlockingSingle is a blocking "version" of Single that provides blocking operators.
BooleanSubscription - Class in rx.subscriptions
Subscription that can be checked for status such as in a loop inside an Observable to exit the loop if unsubscribed.
BooleanSubscription() - Constructor for class rx.subscriptions.BooleanSubscription
 
buffer(Func0<? extends Observable<? extends TClosing>>) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(int) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(int, int) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, TimeUnit, int) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, TimeUnit, int, Scheduler) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(Observable<B>) - Method in class rx.Observable
Returns an Observable that emits non-overlapping buffered items from the source Observable each time the specified boundary Observable emits an item.
buffer(Observable<B>, int) - Method in class rx.Observable
Returns an Observable that emits non-overlapping buffered items from the source Observable each time the specified boundary Observable emits an item.

C

cache() - Method in class rx.Observable
Returns an Observable that subscribes to this Observable lazily, caches all of its events and replays them, in the same order as received, to all the downstream subscribers.
cache(int) - Method in class rx.Observable
cache() - Method in class rx.Single
Returns a Single that subscribes to this Single lazily, caches its success or error event and replays it to all the downstream subscribers.
cacheWithInitialCapacity(int) - Method in class rx.Observable
Returns an Observable that subscribes to this Observable lazily, caches all of its events and replays them, in the same order as received, to all the downstream subscribers.
call() - Method in interface rx.functions.Action0
 
call(T) - Method in interface rx.functions.Action1
 
call(T1, T2) - Method in interface rx.functions.Action2
 
call(T1, T2, T3) - Method in interface rx.functions.Action3
 
call(T1, T2, T3, T4) - Method in interface rx.functions.Action4
 
call(T1, T2, T3, T4, T5) - Method in interface rx.functions.Action5
 
call(T1, T2, T3, T4, T5, T6) - Method in interface rx.functions.Action6
 
call(T1, T2, T3, T4, T5, T6, T7) - Method in interface rx.functions.Action7
 
call(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface rx.functions.Action8
 
call(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface rx.functions.Action9
 
call(Object...) - Method in interface rx.functions.ActionN
 
call() - Method in interface rx.functions.Func0
 
call(T) - Method in interface rx.functions.Func1
 
call(T1, T2) - Method in interface rx.functions.Func2
 
call(T1, T2, T3) - Method in interface rx.functions.Func3
 
call(T1, T2, T3, T4) - Method in interface rx.functions.Func4
 
call(T1, T2, T3, T4, T5) - Method in interface rx.functions.Func5
 
call(T1, T2, T3, T4, T5, T6) - Method in interface rx.functions.Func6
 
call(T1, T2, T3, T4, T5, T6, T7) - Method in interface rx.functions.Func7
 
call(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface rx.functions.Func8
 
call(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface rx.functions.Func9
 
call(Object...) - Method in interface rx.functions.FuncN
 
call(Subscriber<? super T>) - Method in class rx.observables.AsyncOnSubscribe
 
call(Subscriber<? super T>) - Method in class rx.observables.SyncOnSubscribe
 
cancel() - Method in interface rx.functions.Cancellable
Cancel the action or free a resource.
Cancellable - Interface in rx.functions
A functional interface that has a single close method that can throw.
cast(Class<R>) - Method in class rx.Observable
Returns an Observable that emits the items emitted by the source Observable, converted to the specified type.
cast(Class<R>) - Method in class rx.Single
Casts the success value of the current Single into the target type or signals a ClassCastException if not compatible.
clear() - Method in class rx.observers.AsyncCompletableSubscriber
Call to clear the upstream's subscription without unsubscribing it.
clear() - Static method in class rx.plugins.RxJavaHooks
Clears all hooks to be no-op (and pass-through) and onError hook to signal errors to the caller thread's UncaughtExceptionHandler.
clear() - Method in class rx.subscriptions.CompositeSubscription
Unsubscribes any subscriptions that are currently part of this CompositeSubscription and remove them from the CompositeSubscription so that the CompositeSubscription is empty and able to manage new subscriptions.
clearAssemblyTracking() - Static method in class rx.plugins.RxJavaHooks
Clears the assembly tracking hooks to their default pass-through behavior.
collect(Func0<R>, Action2<R, ? super T>) - Method in class rx.Observable
Collects items emitted by the source Observable into a single mutable data structure and returns an Observable that emits this structure.
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.Observable
Combines two source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from either of the source Observables, where this aggregation is defined by a specified function.
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.Observable
Combines three source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Func4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.Observable
Combines four source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Func5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.Observable
Combines five source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Func6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.Observable
Combines six source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Func7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.Observable
Combines seven source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Func8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.Observable
Combines eight source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Observable<? extends T9>, Func9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class rx.Observable
Combines nine source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatest(List<? extends Observable<? extends T>>, FuncN<? extends R>) - Static method in class rx.Observable
Combines a list of source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatest(Iterable<? extends Observable<? extends T>>, FuncN<? extends R>) - Static method in class rx.Observable
Combines a collection of source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
combineLatestDelayError(Iterable<? extends Observable<? extends T>>, FuncN<? extends R>) - Static method in class rx.Observable
Combines a collection of source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function and delays any error from the sources until all source Observables terminate.
Completable - Class in rx
Represents a deferred computation without any value but only indication for completion or exception.
Completable(Completable.OnSubscribe) - Constructor for class rx.Completable
Constructs a Completable instance with the given onSubscribe callback.
Completable(Completable.OnSubscribe, boolean) - Constructor for class rx.Completable
Constructs a Completable instance with the given onSubscribe callback without calling the onCreate hook.
Completable.OnSubscribe - Interface in rx
Callback used for building deferred computations that takes a CompletableSubscriber.
Completable.Operator - Interface in rx
Convenience interface and callback used by the lift operator that given a child CompletableSubscriber, return a parent CompletableSubscriber that does any kind of lifecycle-related transformations.
Completable.Transformer - Interface in rx
Convenience interface and callback used by the compose operator to turn a Completable into another Completable fluently.
CompletableEmitter - Interface in rx
Abstraction over a CompletableSubscriber that gets either an onCompleted or onError signal and allows registering an cancellation/unsubscription callback.
CompletableSubscriber - Interface in rx
Represents the subscription API callbacks when subscribing to a Completable instance.
complete() - Static method in class rx.Completable
Returns a Completable instance that completes immediately when subscribed to.
compose(Completable.Transformer) - Method in class rx.Completable
Calls the given transformer function with this instance and returns the function's resulting Completable.
compose(Observable.Transformer<? super T, ? extends R>) - Method in class rx.Observable
Transform an Observable by applying a particular Transformer function to it.
compose(Single.Transformer<? super T, ? extends R>) - Method in class rx.Single
Transform a Single by applying a particular Transformer function to it.
CompositeException - Exception in rx.exceptions
Represents an exception that is a composite of one or more other exceptions.
CompositeException(String, Collection<? extends Throwable>) - Constructor for exception rx.exceptions.CompositeException
CompositeException(Collection<? extends Throwable>) - Constructor for exception rx.exceptions.CompositeException
Constructs a CompositeException instance with the Throwable elements of the supplied Collection.
CompositeException(Throwable...) - Constructor for exception rx.exceptions.CompositeException
Constructs a CompositeException instance with the supplied initial Throwables.
CompositeSubscription - Class in rx.subscriptions
Subscription that represents a group of Subscriptions that are unsubscribed together.
CompositeSubscription() - Constructor for class rx.subscriptions.CompositeSubscription
Constructs an empty Composite subscription.
CompositeSubscription(Subscription...) - Constructor for class rx.subscriptions.CompositeSubscription
 
computation() - Static method in class rx.schedulers.Schedulers
Creates and returns a Scheduler intended for computational work.
concat(Completable...) - Static method in class rx.Completable
Returns a Completable which completes only when all sources complete, one after another.
concat(Iterable<? extends Completable>) - Static method in class rx.Completable
Returns a Completable which completes only when all sources complete, one after another.
concat(Observable<? extends Completable>) - Static method in class rx.Completable
Returns a Completable which completes only when all sources complete, one after another.
concat(Observable<? extends Completable>, int) - Static method in class rx.Completable
Returns a Completable which completes only when all sources complete, one after another.
concat(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Flattens an Iterable of Observables into one Observable, one after the other, without interleaving them.
concat(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by each of the Observables emitted by the source Observable, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by two Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by three Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by four Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by five Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by six Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by seven Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by eight Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by nine Observables, one after the other, without interleaving them.
concat(Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Returns an Observable that emits the items emitted by two Singles, one after the other.
concat(Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Returns an Observable that emits the items emitted by three Singles, one after the other.
concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Returns an Observable that emits the items emitted by four Singles, one after the other.
concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Returns an Observable that emits the items emitted by five Singles, one after the other.
concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Returns an Observable that emits the items emitted by six Singles, one after the other.
concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Returns an Observable that emits the items emitted by seven Singles, one after the other.
concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Returns an Observable that emits the items emitted by eight Singles, one after the other.
concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Returns an Observable that emits the items emitted by nine Singles, one after the other.
concatDelayError(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Concatenates the Observable sequence of Observables into a single sequence by subscribing to each inner Observable, one after the other, one at a time and delays any errors till the all inner and the outer Observables terminate.
concatDelayError(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Concatenates the Iterable sequence of Observables into a single sequence by subscribing to each Observable, one after the other, one at a time and delays any errors till the all inner Observables terminate.
concatDelayError(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by two Observables, one after the other, without interleaving them, and delays any errors till all Observables terminate.
concatDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by three Observables, one after the other, without interleaving them, and delays any errors till all Observables terminate.
concatDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by four Observables, one after the other, without interleaving them, and delays any errors till all Observables terminate.
concatDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by five Observables, one after the other, without interleaving them, and delays any errors till all Observables terminate.
concatDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by six Observables, one after the other, without interleaving them, and delays any errors till all Observables terminate.
concatDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by seven Observables, one after the other, without interleaving them, and delays any errors till all Observables terminate.
concatDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by eight Observables, one after the other, without interleaving them, and delays any errors till all Observables terminate.
concatDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by nine Observables, one after the other, without interleaving them, and delays any errors till all Observables terminate.
concatEager(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Concatenates two source Observables eagerly into a single stream of values.
concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Concatenates three sources eagerly into a single stream of values.
concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Concatenates four sources eagerly into a single stream of values.
concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Concatenates five sources eagerly into a single stream of values.
concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Concatenates six sources eagerly into a single stream of values.
concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Concatenates seven sources eagerly into a single stream of values.
concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Concatenates eight sources eagerly into a single stream of values.
concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Concatenates nine sources eagerly into a single stream of values.
concatEager(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Concatenates a sequence of Observables eagerly into a single stream of values.
concatEager(Iterable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
Concatenates a sequence of Observables eagerly into a single stream of values.
concatEager(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Concatenates an Observable sequence of Observables eagerly into a single stream of values.
concatEager(Observable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
Concatenates an Observable sequence of Observables eagerly into a single stream of values.
concatMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Returns a new Observable that emits items resulting from applying a function that you supply to each item emitted by the source Observable, where that function returns an Observable, and then emitting the items that result from concatenating those resulting Observables.
concatMapDelayError(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Maps each of the items into an Observable, 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 Observables till all of them terminate.
concatMapEager(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Maps a sequence of values into Observables and concatenates these Observables eagerly into a single Observable.
concatMapEager(Func1<? super T, ? extends Observable<? extends R>>, int) - Method in class rx.Observable
Maps a sequence of values into Observables and concatenates these Observables eagerly into a single Observable.
concatMapEager(Func1<? super T, ? extends Observable<? extends R>>, int, int) - Method in class rx.Observable
Maps a sequence of values into Observables and concatenates these Observables eagerly into a single Observable.
concatMapIterable(Func1<? super T, ? extends Iterable<? extends R>>) - Method in class rx.Observable
Returns an Observable that concatenate each item emitted by the source Observable with the values in an Iterable corresponding to that item that is generated by a selector.
concatWith(Completable) - Method in class rx.Completable
Concatenates this Completable with another Completable.
concatWith(Observable<? extends T>) - Method in class rx.Observable
Returns an Observable that emits the items emitted from the current Observable, then the next, one after the other, without interleaving them.
concatWith(Single<? extends T>) - Method in class rx.Single
Returns an Observable that emits the item emitted by the source Single, then the item emitted by the specified Single.
connect() - Method in class rx.observables.ConnectableObservable
Instructs the ConnectableObservable to begin emitting the items from its underlying Observable to its Subscribers.
connect(Action1<? super Subscription>) - Method in class rx.observables.ConnectableObservable
Instructs the ConnectableObservable to begin emitting the items from its underlying Observable to its Subscribers.
ConnectableObservable<T> - Class in rx.observables
A ConnectableObservable resembles an ordinary Observable, except that it does not begin emitting items when it is subscribed to, but only when its ConnectableObservable.connect() method is called.
ConnectableObservable(Observable.OnSubscribe<T>) - Constructor for class rx.observables.ConnectableObservable
 
contains(Object) - Method in class rx.Observable
Returns an Observable that emits a Boolean that indicates whether the source Observable emitted a specified item.
count() - Method in class rx.Observable
Returns an Observable that emits the count of the total number of items emitted by the source Observable.
countLong() - Method in class rx.Observable
Returns an Observable that counts the total number of items emitted by the source Observable and emits this count as a 64-bit Long.
create(Completable.OnSubscribe) - Static method in class rx.Completable
Constructs a Completable instance by wrapping the given onSubscribe callback.
create(Observable.OnSubscribe<T>) - Static method in class rx.Observable
Deprecated.
1.2.7 - inherently unsafe, use the other create() methods for basic cases or see Observable.unsafeCreate(OnSubscribe) for advanced cases (such as custom operators)
create(Action1<Emitter<T>>, Emitter.BackpressureMode) - Static method in class rx.Observable
Provides an API (via a cold Observable) that bridges the reactive world with the callback-style, generally non-backpressured world.
create(SyncOnSubscribe<S, T>) - Static method in class rx.Observable
Returns an Observable that respects the back-pressure semantics.
create(AsyncOnSubscribe<S, T>) - Static method in class rx.Observable
Returns an Observable that respects the back-pressure semantics.
create(K, Observable.OnSubscribe<T>) - Static method in class rx.observables.GroupedObservable
Returns an Observable that will execute the specified function when a Subscriber subscribes to it.
create(Action1<? super T>) - Static method in class rx.observers.Observers
Creates an Observer that receives the emissions of any Observable it subscribes to via onNext but ignores onCompleted notifications; it will throw an OnErrorNotImplementedException if onError is invoked.
create(Action1<? super T>, Action1<Throwable>) - Static method in class rx.observers.Observers
Creates an Observer that receives the emissions of any Observable it subscribes to via onNext and handles any onError notification but ignores an onCompleted notification.
create(Action1<? super T>, Action1<Throwable>, Action0) - Static method in class rx.observers.Observers
Creates an Observer that receives the emissions of any Observable it subscribes to via onNext and handles any onError or onCompleted notifications.
create(Action1<? super T>) - Static method in class rx.observers.Subscribers
Creates a Subscriber that receives the emissions of any Observable it subscribes to via onNext but ignores onCompleted notifications; it will throw an OnErrorNotImplementedException if onError is invoked.
create(Action1<? super T>, Action1<Throwable>) - Static method in class rx.observers.Subscribers
Creates an Subscriber that receives the emissions of any Observable it subscribes to via onNext and handles any onError notification but ignores an onCompleted notification.
create(Action1<? super T>, Action1<Throwable>, Action0) - Static method in class rx.observers.Subscribers
Creates an Subscriber that receives the emissions of any Observable it subscribes to via onNext and handles any onError or onCompleted notifications.
create() - Static method in class rx.observers.TestSubscriber
Factory method to construct a TestSubscriber with an initial request of Long.MAX_VALUE and no delegation.
create(long) - Static method in class rx.observers.TestSubscriber
Factory method to construct a TestSubscriber with the given initial request amount and no delegation.
create(Observer<T>, long) - Static method in class rx.observers.TestSubscriber
Factory method to construct a TestSubscriber which delegates events to the given Observer and issues the given initial request amount.
create(Subscriber<T>) - Static method in class rx.observers.TestSubscriber
Factory method to construct a TestSubscriber which delegates events to the given Subscriber and an issues an initial request of Long.MAX_VALUE.
create(Observer<T>) - Static method in class rx.observers.TestSubscriber
Factory method to construct a TestSubscriber which delegates events to the given Observer and an issues an initial request of Long.MAX_VALUE.
create(Single.OnSubscribe<T>) - Static method in class rx.Single
Returns a Single that will execute the specified function when a SingleSubscriber executes it or a Subscriber subscribes to it.
create() - Static method in class rx.subjects.AsyncSubject
Creates and returns a new AsyncSubject.
create() - Static method in class rx.subjects.BehaviorSubject
Creates a BehaviorSubject without a default item.
create(T) - Static method in class rx.subjects.BehaviorSubject
Creates a BehaviorSubject that emits the last item it observed and all subsequent items to each Observer that subscribes to it.
create() - Static method in class rx.subjects.PublishSubject
Creates and returns a new PublishSubject.
create() - Static method in class rx.subjects.ReplaySubject
Creates an unbounded replay subject.
create(int) - Static method in class rx.subjects.ReplaySubject
Creates an unbounded replay subject with the specified initial buffer capacity.
create(TestScheduler) - Static method in class rx.subjects.TestSubject
Creates and returns a new TestSubject.
create() - Static method in class rx.subjects.UnicastSubject
Constructs an empty UnicastSubject instance with the default capacity hint of 16 elements.
create(int) - Static method in class rx.subjects.UnicastSubject
Constructs an empty UnicastSubject instance with a capacity hint.
create(boolean) - Static method in class rx.subjects.UnicastSubject
Constructs an empty UnicastSubject instance with the default capacity hint of 16 elements.
create(int, Action0) - Static method in class rx.subjects.UnicastSubject
Constructs an empty UnicastSubject instance with a capacity hint and an Action0 instance to call if the subject reaches its terminal state or the single Subscriber unsubscribes mid-sequence.
create(int, Action0, boolean) - Static method in class rx.subjects.UnicastSubject
Constructs an empty UnicastSubject instance with a capacity hint, delay error flag and Action0 instance to call if the subject reaches its terminal state or the single Subscriber unsubscribes mid-sequence.
create() - Static method in class rx.subscriptions.BooleanSubscription
Creates a BooleanSubscription without unsubscribe behavior.
create(Action0) - Static method in class rx.subscriptions.BooleanSubscription
Creates a BooleanSubscription with a specified function to invoke upon unsubscribe.
create(Action0) - Static method in class rx.subscriptions.Subscriptions
Creates and returns a Subscription that invokes the given Action0 when unsubscribed.
createComputationScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
Create an instance of the default Scheduler used for Schedulers.computation().
createComputationScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
Create an instance of the default Scheduler used for Schedulers.computation() except using threadFactory for thread creation.
createIoScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
Create an instance of the default Scheduler used for Schedulers.io().
createIoScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
Create an instance of the default Scheduler used for Schedulers.io() except using threadFactory for thread creation.
createNewThreadScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
Create an instance of the default Scheduler used for Schedulers.newThread().
createNewThreadScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
Create an instance of the default Scheduler used for Schedulers.newThread() except using threadFactory for thread creation.
createOnCompleted() - Static method in class rx.Notification
Creates and returns a Notification of variety Kind.OnCompleted.
createOnCompleted(Class<T>) - Static method in class rx.Notification
Deprecated.
this method does the same as Notification.createOnCompleted() and does not use the passed in type hence it's useless.
createOnError(Throwable) - Static method in class rx.Notification
Creates and returns a Notification of variety Kind.OnError, and assigns it an exception.
createOnNext(T) - Static method in class rx.Notification
Creates and returns a Notification of variety Kind.OnNext, and assigns it a value.
createSingleState(Func0<? extends S>, Action3<? super S, Long, ? super Observer<Observable<? extends T>>>) - Static method in class rx.observables.AsyncOnSubscribe
Generates a synchronous AsyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createSingleState(Func0<? extends S>, Action3<? super S, Long, ? super Observer<Observable<? extends T>>>, Action1<? super S>) - Static method in class rx.observables.AsyncOnSubscribe
Generates a synchronous AsyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createSingleState(Func0<? extends S>, Action2<? super S, ? super Observer<? super T>>) - Static method in class rx.observables.SyncOnSubscribe
Generates a synchronous SyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createSingleState(Func0<? extends S>, Action2<? super S, ? super Observer<? super T>>, Action1<? super S>) - Static method in class rx.observables.SyncOnSubscribe
Generates a synchronous SyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createStateful(Func0<? extends S>, Func3<? super S, Long, ? super Observer<Observable<? extends T>>, ? extends S>, Action1<? super S>) - Static method in class rx.observables.AsyncOnSubscribe
Generates a synchronous AsyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createStateful(Func0<? extends S>, Func3<? super S, Long, ? super Observer<Observable<? extends T>>, ? extends S>) - Static method in class rx.observables.AsyncOnSubscribe
Generates a synchronous AsyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createStateful(Func0<? extends S>, Func2<? super S, ? super Observer<? super T>, ? extends S>, Action1<? super S>) - Static method in class rx.observables.SyncOnSubscribe
Generates a synchronous SyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createStateful(Func0<? extends S>, Func2<? super S, ? super Observer<? super T>, ? extends S>) - Static method in class rx.observables.SyncOnSubscribe
Generates a synchronous SyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createStateless(Action2<Long, ? super Observer<Observable<? extends T>>>) - Static method in class rx.observables.AsyncOnSubscribe
Generates a synchronous AsyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createStateless(Action2<Long, ? super Observer<Observable<? extends T>>>, Action0) - Static method in class rx.observables.AsyncOnSubscribe
Generates a synchronous AsyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createStateless(Action1<? super Observer<? super T>>) - Static method in class rx.observables.SyncOnSubscribe
Generates a synchronous SyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createStateless(Action1<? super Observer<? super T>>, Action0) - Static method in class rx.observables.SyncOnSubscribe
Generates a synchronous SyncOnSubscribe that calls the provided next function to generate data to downstream subscribers.
createWithSize(int) - Static method in class rx.subjects.ReplaySubject
Creates a size-bounded replay subject.
createWithTime(long, TimeUnit, Scheduler) - Static method in class rx.subjects.ReplaySubject
Creates a time-bounded replay subject.
createWithTimeAndSize(long, TimeUnit, int, Scheduler) - Static method in class rx.subjects.ReplaySubject
Creates a time- and size-bounded replay subject.
createWorker() - Method in class rx.Scheduler
Retrieves or creates a new Scheduler.Worker that represents serial execution of actions.
createWorker() - Method in class rx.schedulers.ImmediateScheduler
Deprecated.
 
createWorker() - Method in class rx.schedulers.NewThreadScheduler
Deprecated.
 
createWorker() - Method in class rx.schedulers.TestScheduler
 
createWorker() - Method in class rx.schedulers.TrampolineScheduler
Deprecated.
 

D

debounce(Func1<? super T, ? extends Observable<U>>) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, except that it drops items emitted by the source Observable that are followed by another item within a computed debounce duration.
debounce(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, except that it drops items emitted by the source Observable that are followed by newer items before a timeout value expires.
debounce(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, except that it drops items emitted by the source Observable that are followed by newer items before a timeout value expires on a specified Scheduler.
defaultIfEmpty(T) - Method in class rx.Observable
Returns an Observable that emits the items emitted by the source Observable or a specified default item if the source Observable is empty.
defer(Func0<? extends Completable>) - Static method in class rx.Completable
Defers the subscription to a Completable instance returned by a supplier.
defer(Func0<Observable<T>>) - Static method in class rx.Observable
Returns an Observable that calls an Observable factory to create an Observable for each new Observer that subscribes.
defer(Callable<Single<T>>) - Static method in class rx.Single
Returns a Single that calls a Single factory to create a Single for each new Observer that subscribes.
delay(long, TimeUnit) - Method in class rx.Completable
Returns a Completable which delays the emission of the completion event by the given time.
delay(long, TimeUnit, Scheduler) - Method in class rx.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 rx.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(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>) - Method in class rx.Observable
Returns an Observable that delays the subscription to and emissions from the source Observable via another Observable on a per-item basis.
delay(Func1<? super T, ? extends Observable<U>>) - Method in class rx.Observable
Returns an Observable that delays the emissions of the source Observable via another Observable on a per-item basis.
delay(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits the items emitted by the source Observable shifted forward in time by a specified delay.
delay(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits the items emitted by the source Observable shifted forward in time by a specified delay.
delay(long, TimeUnit, Scheduler) - Method in class rx.Single
Returns a Single that emits the items emitted by the source Single shifted forward in time by a specified delay.
delay(long, TimeUnit) - Method in class rx.Single
Returns a Single that emits the items emitted by the source Single shifted forward in time by a specified delay.
delaySubscription(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that delays the subscription to the source Observable by a given amount of time.
delaySubscription(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that delays the subscription to the source Observable by a given amount of time, both waiting and subscribing on a given Scheduler.
delaySubscription(Func0<? extends Observable<U>>) - Method in class rx.Observable
Returns an Observable that delays the subscription to the source Observable until a second Observable emits an item.
delaySubscription(Observable<U>) - Method in class rx.Observable
Returns an Observable that delays the subscription to this Observable until the other Observable emits an element or completes normally.
delaySubscription(Observable<?>) - Method in class rx.Single
Returns a Single that delays the subscription to this Single until the Observable completes.
dematerialize() - Method in class rx.Observable
Returns an Observable that reverses the effect of materialize by transforming the Notification objects emitted by the source Observable into the items or notifications they represent.
distinct() - Method in class rx.Observable
Returns an Observable that emits all items emitted by the source Observable that are distinct.
distinct(Func1<? super T, ? extends U>) - Method in class rx.Observable
Returns an Observable that emits all items emitted by the source Observable that are distinct according to a key selector function.
distinctUntilChanged() - Method in class rx.Observable
Returns an Observable that emits all items emitted by the source Observable that are distinct from their immediate predecessors.
distinctUntilChanged(Func1<? super T, ? extends U>) - Method in class rx.Observable
Returns an Observable that emits all items emitted by the source Observable that are distinct from their immediate predecessors, according to a key selector function.
distinctUntilChanged(Func2<? super T, ? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits all items emitted by the source Observable that are distinct from their immediate predecessors when compared with each other via the provided comparator function.
doAfterTerminate(Action0) - Method in class rx.Completable
Returns a Completable instance that calls the given onAfterComplete callback after this Completable completes normally.
doAfterTerminate(Action0) - Method in class rx.Observable
Registers an Action0 to be called when this Observable invokes either onCompleted or onError.
doAfterTerminate(Action0) - Method in class rx.Single
Registers an Action0 to be called when this Single invokes either SingleSubscriber.onSuccess(Object) onSuccess} or onError.
doOnCompleted(Action0) - Method in class rx.Completable
Returns a Completable which calls the given onCompleted callback if this Completable completes.
doOnCompleted(Action0) - Method in class rx.Observable
Modifies the source Observable so that it invokes an action when it calls onCompleted.
doOnEach(Action1<Notification<Object>>) - Method in class rx.Completable
Returns a Completable which calls the given onNotification callback when this Completable emits an error or completes.
doOnEach(Action1<Notification<? super T>>) - Method in class rx.Observable
Modifies the source Observable so that it invokes an action for each item and terminal event it emits.
doOnEach(Observer<? super T>) - Method in class rx.Observable
Modifies the source Observable so that it notifies an Observer for each item and terminal event it emits.
doOnEach(Action1<Notification<? extends T>>) - Method in class rx.Single
Modifies the source Single so that it invokes an action when it calls onSuccess or onError.
doOnError(Action1<? super Throwable>) - Method in class rx.Completable
Returns a Completable which calls the given onError callback if this Completable emits an error.
doOnError(Action1<? super Throwable>) - Method in class rx.Observable
Modifies the source Observable so that it invokes an action if it calls onError.
doOnError(Action1<Throwable>) - Method in class rx.Single
Modifies the source Single so that it invokes an action if it calls onError.
doOnLifecycle(Action1<? super Subscription>, Action1<? super Throwable>, Action0, Action0, Action0) - Method in class rx.Completable
Returns a Completable instance that calls the various callbacks on the specific lifecycle events.
doOnNext(Action1<? super T>) - Method in class rx.Observable
Modifies the source Observable so that it invokes an action when it calls onNext.
doOnRequest(Action1<? super Long>) - Method in class rx.Observable
Modifies the source Observable so that it invokes the given action when it receives a request for more items.
doOnSubscribe(Action1<? super Subscription>) - Method in class rx.Completable
Returns a Completable instance that calls the given onSubscribe callback with the disposable that child subscribers receive on subscription.
doOnSubscribe(Action0) - Method in class rx.Observable
Modifies the source Observable so that it invokes the given action when it is subscribed from its subscribers.
doOnSubscribe(Action0) - Method in class rx.Single
Modifies the source Single so that it invokes the given action when it is subscribed from its subscribers.
doOnSuccess(Action1<? super T>) - Method in class rx.Single
Modifies the source Single so that it invokes an action when it calls onSuccess.
doOnTerminate(Action0) - Method in class rx.Completable
Returns a Completable instance that calls the given onTerminate callback just before this Completable completes normally or with an exception
doOnTerminate(Action0) - Method in class rx.Observable
Modifies the source Observable so that it invokes an action when it calls onCompleted or onError.
doOnUnsubscribe(Action0) - Method in class rx.Completable
Returns a Completable which calls the given onUnsubscribe callback if the child subscriber cancels the subscription.
doOnUnsubscribe(Action0) - Method in class rx.Observable
Calls the unsubscribe Action0 if the downstream unsubscribes the sequence.
doOnUnsubscribe(Action0) - Method in class rx.Single
Modifies the source Single so that it invokes the given action when it is unsubscribed from its subscribers.

E

elementAt(int) - Method in class rx.Observable
Returns an Observable that emits the single item at a specified index in a sequence of emissions from a source Observable.
elementAtOrDefault(int, T) - Method in class rx.Observable
Returns an Observable that emits the item found at a specified index in a sequence of emissions from a source Observable, or a default item if that index is out of range.
Emitter<T> - Interface in rx
Abstraction over a RxJava Subscriber that allows associating a resource with it and exposes the current number of downstream requested amount.
Emitter.BackpressureMode - Enum in rx
Options to handle backpressure in the emitter.
empty() - Static method in class rx.functions.Actions
 
empty() - Static method in class rx.Observable
Returns an Observable that emits no items to the Observer and immediately invokes its onCompleted method.
empty() - Static method in class rx.observers.Observers
Returns an inert Observer that does nothing in response to the emissions or notifications from any Observable it subscribes to but will throw an exception if its onError method is called.
empty() - Static method in class rx.observers.Subscribers
Returns an inert Subscriber that does nothing in response to the emissions or notifications from any Observable it subscribes to.
empty() - Static method in class rx.subscriptions.Subscriptions
Returns a Subscription to which unsubscribe does nothing except to change isUnsubscribed to true.
enableAssemblyTracking() - Static method in class rx.plugins.RxJavaHooks
Sets up hooks that capture the current stacktrace when a source or an operator is instantiated, keeping it in a field for debugging purposes and alters exceptions passing along to hold onto this stacktrace.
equals(Object) - Method in class rx.Notification
 
equals(Object) - Method in class rx.schedulers.TimeInterval
 
equals(Object) - Method in class rx.schedulers.Timestamped
 
error(Func0<? extends Throwable>) - Static method in class rx.Completable
Creates a Completable which calls the given error supplier for each subscriber and emits its returned Throwable.
error(Throwable) - Static method in class rx.Completable
Creates a Completable instance that emits the given Throwable exception to subscribers.
error(Throwable) - Static method in class rx.Observable
Returns an Observable that invokes an Observer's onError method when the Observer subscribes to it.
error(Throwable) - Static method in class rx.Single
Returns a Single that invokes a subscriber's onError method when the subscriber subscribes to it.
ERROR_IN_RENDERING_SUFFIX - Static variable in class rx.plugins.RxJavaErrorHandler
 
errorNotImplemented() - Static method in class rx.functions.Actions
Returns an action which throws OnErrorNotImplementedException.
Exceptions - Class in rx.exceptions
Utility class with methods to wrap checked exceptions and manage fatal and regular exception delivery.
exists(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits true if any item emitted by the source Observable satisfies a specified condition, otherwise false.
Experimental - Annotation Type in rx.annotations
Signifies that a public API (public class, method or field) is will almost certainly be changed or removed in a future release.

F

fillInStackTrace() - Method in exception rx.exceptions.AssemblyStackTraceException
 
filter(Func1<? super T, Boolean>) - Method in class rx.Observable
Filters items emitted by an Observable by only emitting those that satisfy a specified predicate.
finallyDo(Action0) - Method in class rx.Observable
Deprecated.
find(Throwable) - Static method in exception rx.exceptions.AssemblyStackTraceException
Locate the first AssemblyStackTraceException in the causal chain of the given Throwable (or it if it's one).
first() - Method in class rx.Observable
Returns an Observable that emits only the very first item emitted by the source Observable, or notifies of an NoSuchElementException if the source Observable is empty.
first(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits only the very first item emitted by the source Observable that satisfies a specified condition, or notifies of an NoSuchElementException if no such items are emitted.
first() - Method in class rx.observables.BlockingObservable
Returns the first item emitted by this BlockingObservable, or throws NoSuchElementException if it emits no items.
first(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the first item emitted by this BlockingObservable that matches a predicate, or throws NoSuchElementException if it emits no such item.
firstOrDefault(T) - Method in class rx.Observable
Returns an Observable that emits only the very first item emitted by the source Observable, or a default item if the source Observable completes without emitting anything.
firstOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits only the very first item emitted by the source Observable that satisfies a specified condition, or a default item if the source Observable emits no such items.
firstOrDefault(T) - Method in class rx.observables.BlockingObservable
Returns the first item emitted by this BlockingObservable, or a default value if it emits no items.
firstOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the first item emitted by this BlockingObservable that matches a predicate, or a default value if it emits no such items.
flatMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source Observable, where that function returns an Observable, and then merging those resulting Observables and emitting the results of this merger.
flatMap(Func1<? super T, ? extends Observable<? extends R>>, int) - Method in class rx.Observable
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source Observable, where that function returns an Observable, and then merging those resulting Observables and emitting the results of this merger, while limiting the maximum number of concurrent subscriptions to these Observables.
flatMap(Func1<? super T, ? extends Observable<? extends R>>, Func1<? super Throwable, ? extends Observable<? extends R>>, Func0<? extends Observable<? extends R>>) - Method in class rx.Observable
Returns an Observable that applies a function to each item emitted or notification raised by the source Observable and then flattens the Observables returned from these functions and emits the resulting items.
flatMap(Func1<? super T, ? extends Observable<? extends R>>, Func1<? super Throwable, ? extends Observable<? extends R>>, Func0<? extends Observable<? extends R>>, int) - Method in class rx.Observable
Returns an Observable that applies a function to each item emitted or notification raised by the source Observable and then flattens the Observables returned from these functions and emits the resulting items, while limiting the maximum number of concurrent subscriptions to these Observables.
flatMap(Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>) - Method in class rx.Observable
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source Observable and a specified collection Observable.
flatMap(Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>, int) - Method in class rx.Observable
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source Observable and a specified collection Observable, while limiting the maximum number of concurrent subscriptions to these Observables.
flatMap(Func1<? super T, ? extends Single<? extends R>>) - Method in class rx.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 Single.
flatMapCompletable(Func1<? super T, ? extends Completable>) - Method in class rx.Observable
Maps all upstream values to Completables and runs them together until the upstream and all inner Completables complete normally.
flatMapCompletable(Func1<? super T, ? extends Completable>, boolean) - Method in class rx.Observable
Maps all upstream values to Completables and runs them together, optionally delaying any errors, until the upstream and all inner Completables terminate.
flatMapCompletable(Func1<? super T, ? extends Completable>, boolean, int) - Method in class rx.Observable
Maps upstream values to Completables and runs up to the given number of them together at a time, optionally delaying any errors, until the upstream and all inner Completables terminate.
flatMapCompletable(Func1<? super T, ? extends Completable>) - Method in class rx.Single
Returns a Completable that completes based on applying a specified function to the item emitted by the source Completable, where that function returns a Completable.
flatMapIterable(Func1<? super T, ? extends Iterable<? extends R>>) - Method in class rx.Observable
Returns an Observable that merges each item emitted by the source Observable with the values in an Iterable corresponding to that item that is generated by a selector.
flatMapIterable(Func1<? super T, ? extends Iterable<? extends R>>, int) - Method in class rx.Observable
Returns an Observable that merges each item emitted by the source Observable 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 Observables.
flatMapIterable(Func1<? super T, ? extends Iterable<? extends U>>, Func2<? super T, ? super U, ? extends R>) - Method in class rx.Observable
Returns an Observable that emits the results of applying a function to the pair of values from the source Observable and an Iterable corresponding to that item that is generated by a selector.
flatMapIterable(Func1<? super T, ? extends Iterable<? extends U>>, Func2<? super T, ? super U, ? extends R>, int) - Method in class rx.Observable
Returns an Observable that emits the results of applying a function to the pair of values from the source Observable and an Iterable corresponding to that item that is generated by a selector, while limiting the number of concurrent subscriptions to these Observables.
flatMapObservable(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Single
Returns an Observable that emits items based on applying a specified function to the item emitted by the source Observable, where that function returns an Observable.
flatMapSingle(Func1<? super T, ? extends Single<? extends R>>) - Method in class rx.Observable
Maps all upstream values to Singles and runs them together until the upstream and all inner Singles complete normally.
flatMapSingle(Func1<? super T, ? extends Single<? extends R>>, boolean) - Method in class rx.Observable
Maps all upstream values to Singles and runs them together, optionally delaying any errors, until the upstream and all inner Singles terminate.
flatMapSingle(Func1<? super T, ? extends Single<? extends R>>, boolean, int) - Method in class rx.Observable
Maps upstream values to Singles and runs up to the given number of them together at a time, optionally delaying any errors, until the upstream and all inner Singles terminate.
forEach(Action1<? super T>) - Method in class rx.Observable
Subscribes to the Observable and receives notifications for each element.
forEach(Action1<? super T>, Action1<Throwable>) - Method in class rx.Observable
Subscribes to the Observable and receives notifications for each element and error events.
forEach(Action1<? super T>, Action1<Throwable>, Action0) - Method in class rx.Observable
Subscribes to the Observable and receives notifications for each element and the terminal events.
forEach(Action1<? super T>) - Method in class rx.observables.BlockingObservable
Invokes a method on each item emitted by this BlockingObservable and blocks until the Observable completes.
from(Throwable) - Static method in exception rx.exceptions.OnErrorThrowable
Converts a Throwable into an OnErrorThrowable.
from(Future<? extends T>) - Static method in class rx.Observable
Converts a Future into an Observable.
from(Future<? extends T>, long, TimeUnit) - Static method in class rx.Observable
Converts a Future into an Observable, with a timeout on the Future.
from(Future<? extends T>, Scheduler) - Static method in class rx.Observable
Converts a Future, operating on a specified Scheduler, into an Observable.
from(Iterable<? extends T>) - Static method in class rx.Observable
Converts an Iterable sequence into an Observable that emits the items in the sequence.
from(T[]) - Static method in class rx.Observable
Converts an Array into an Observable that emits the items in the Array.
from(Observable<? extends T>) - Static method in class rx.observables.BlockingObservable
Converts an Observable into a BlockingObservable.
from(K, Observable<T>) - Static method in class rx.observables.GroupedObservable
Converts an Observable into a GroupedObservable with a particular key.
from(Observer<? super T>) - Static method in class rx.observers.Subscribers
Converts an Observer into a Subscriber.
from(Executor) - Static method in class rx.schedulers.Schedulers
Converts an Executor into a new Scheduler instance.
from(Future<? extends T>) - Static method in class rx.Single
Converts a Future into a Single.
from(Future<? extends T>, long, TimeUnit) - Static method in class rx.Single
Converts a Future into a Single, with a timeout on the Future.
from(Future<? extends T>, Scheduler) - Static method in class rx.Single
Converts a Future, operating on a specified Scheduler, into a Single.
from(Single<? extends T>) - Static method in class rx.singles.BlockingSingle
Converts a Single into a BlockingSingle.
from(Future<?>) - Static method in class rx.subscriptions.Subscriptions
Converts a Future into a Subscription and cancels it when unsubscribed.
from(Subscription...) - Static method in class rx.subscriptions.Subscriptions
Converts a set of Subscriptions into a CompositeSubscription that groups the multiple Subscriptions together and unsubscribes from all of them together.
fromAction(Action0) - Static method in class rx.Completable
Returns a Completable instance that runs the given Action0 for each subscriber and emits either an unchecked exception or simply completes.
fromAction(Action0) - Static method in class rx.functions.Functions
Converts an Action0 to a FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action1<? super T0>) - Static method in class rx.functions.Functions
Converts an Action1 to a FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action2<? super T0, ? super T1>) - Static method in class rx.functions.Functions
Converts an Action2 to a FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action3<? super T0, ? super T1, ? super T2>) - Static method in class rx.functions.Functions
Converts an Action3 to a FuncN to allow heterogeneous handling of functions with different arities.
fromCallable(Callable<?>) - Static method in class rx.Completable
Returns a Completable which when subscribed, executes the callable function, ignores its normal result and emits onError or onCompleted only.
fromCallable(Callable<? extends T>) - Static method in class rx.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 rx.Single
Returns a Single that invokes passed function and emits its result for each new Observer that subscribes.
fromEmitter(Action1<CompletableEmitter>) - Static method in class rx.Completable
Provides an API (in a cold Completable) that bridges the Completable-reactive world with the callback-based world.
fromEmitter(Action1<SingleEmitter<T>>) - Static method in class rx.Single
Provides an API (in a cold Single) that bridges the Single-reactive world with the callback-based world.
fromFunc(Func0<? extends R>) - Static method in class rx.functions.Functions
Converts a Func0 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func1<? super T0, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func1 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func2<? super T0, ? super T1, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func2 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func3<? super T0, ? super T1, ? super T2, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func3 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func4<? super T0, ? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func4 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func5<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func5 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func6<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func6 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func7<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func7 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func8<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func8 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func9<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.functions.Functions
Converts a Func9 to a FuncN to allow heterogeneous handling of functions with different arities.
fromFuture(Future<?>) - Static method in class rx.Completable
Returns a Completable instance that reacts to the termination of the given Future in a blocking fashion.
fromObservable(Observable<?>) - Static method in class rx.Completable
Returns a Completable instance that subscribes to the given flowable, ignores all values and emits only the terminal event.
fromSingle(Single<?>) - Static method in class rx.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.
Func0<R> - Interface in rx.functions
Represents a function with zero arguments.
Func1<T,R> - Interface in rx.functions
Represents a function with one argument.
Func2<T1,T2,R> - Interface in rx.functions
Represents a function with two arguments.
Func3<T1,T2,T3,R> - Interface in rx.functions
Represents a function with three arguments.
Func4<T1,T2,T3,T4,R> - Interface in rx.functions
Represents a function with four arguments.
Func5<T1,T2,T3,T4,T5,R> - Interface in rx.functions
Represents a function with five arguments.
Func6<T1,T2,T3,T4,T5,T6,R> - Interface in rx.functions
Represents a function with six arguments.
Func7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in rx.functions
Represents a function with seven arguments.
Func8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in rx.functions
Represents a function with eight arguments.
Func9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in rx.functions
Represents a function with nine arguments.
FuncN<R> - Interface in rx.functions
Represents a vector-argument function.
Function - Interface in rx.functions
All Func and Action interfaces extend from this.
Functions - Class in rx.functions
 

G

generateState() - Method in class rx.observables.AsyncOnSubscribe
Executed once when subscribed to by a subscriber (via AsyncOnSubscribe.call(Subscriber)) to produce a state value.
generateState() - Method in class rx.observables.SyncOnSubscribe
Executed once when subscribed to by a subscriber (via SyncOnSubscribe.call(Subscriber)) to produce a state value.
get() - Method in class rx.Completable
Subscribes to this Completable instance and blocks until it terminates, then returns null or the emitted exception if any.
get(long, TimeUnit) - Method in class rx.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.
get() - Method in class rx.subscriptions.MultipleAssignmentSubscription
Gets the underlying subscription.
get() - Method in class rx.subscriptions.RefCountSubscription
Returns a new sub-subscription
get() - Method in class rx.subscriptions.SerialSubscription
Gets the underlying subscription.
getActual() - Method in class rx.observers.SafeSubscriber
Returns the Subscriber underlying this SafeSubscriber.
getCause() - Method in exception rx.exceptions.CompositeException
 
getCompletableExecutionHook() - Method in class rx.plugins.RxJavaPlugins
Retrieves the instance of RxJavaCompletableExecutionHook to use based on order of precedence as defined in RxJavaPlugins class header.
getCompletions() - Method in interface rx.observers.AssertableSubscriber
Returns the number of onCompleted signals received by this Observer.
getCompletions() - Method in class rx.observers.TestSubscriber
Returns the number of times onCompleted was called on this TestSubscriber.
getComputationScheduler() - Method in class rx.plugins.RxJavaSchedulersHook
Scheduler to return from Schedulers.computation() or null if default should be used.
getDefaultInstance() - Static method in class rx.plugins.RxJavaSchedulersHook
 
getErrorHandler() - Method in class rx.plugins.RxJavaPlugins
Retrieves an instance of RxJavaErrorHandler to use based on order of precedence as defined in RxJavaPlugins class header.
getEvents() - Method in class rx.observers.TestObserver
Deprecated.
Get a list containing all of the items and notifications received by this observer, where the items will be given as-is, any error notifications will be represented by their Throwables, and any sequence-complete notifications will be represented by their Notification objects.
getExceptions() - Method in exception rx.exceptions.CompositeException
Retrieves the list of exceptions that make up the CompositeException
getFinalCause(Throwable) - Static method in class rx.exceptions.Exceptions
Get the Throwable at the end of the causality-chain for a particular Throwable
getInstance() - Static method in class rx.plugins.RxJavaPlugins
Deprecated.
use the static methods of RxJavaHooks.
getIntervalInMilliseconds() - Method in class rx.schedulers.TimeInterval
Returns the time interval, expressed in milliseconds.
getIOScheduler() - Method in class rx.plugins.RxJavaSchedulersHook
Scheduler to return from Schedulers.io() or null if default should be used.
getIterator() - Method in class rx.observables.BlockingObservable
Returns an Iterator that iterates over all items emitted by this BlockingObservable.
getKey() - Method in class rx.observables.GroupedObservable
Returns the key that identifies the group of items emitted by this GroupedObservable
getKind() - Method in class rx.Notification
Retrieves the kind of this notification: OnNext, OnError, or OnCompleted
getLastSeenThread() - Method in interface rx.observers.AssertableSubscriber
Returns the Thread that has called the last onNext, onError or onCompleted methods of this Observer.
getLastSeenThread() - Method in class rx.observers.TestSubscriber
Returns the last thread that was in use when an item or notification was received by this Subscriber.
getMessage() - Method in exception rx.exceptions.CompositeException
 
getNewThreadScheduler() - Method in class rx.plugins.RxJavaSchedulersHook
Scheduler to return from Schedulers.newThread() or null if default should be used.
getObservableExecutionHook() - Method in class rx.plugins.RxJavaPlugins
Retrieves the instance of RxJavaObservableExecutionHook to use based on order of precedence as defined in RxJavaPlugins class header.
getOnCompletableCreate() - Static method in class rx.plugins.RxJavaHooks
Returns the current Completable onCreate hook function or null if it is set to the default pass-through.
getOnCompletableLift() - Static method in class rx.plugins.RxJavaHooks
Returns the current Completable onLift hook function or null if it is set to the default pass-through.
getOnCompletableStart() - Static method in class rx.plugins.RxJavaHooks
Returns the current Completable onStart hook function or null if it is set to the default pass-through.
getOnCompletableSubscribeError() - Static method in class rx.plugins.RxJavaHooks
Returns the current Completable onSubscribeError hook function or null if it is set to the default pass-through.
getOnCompletedEvents() - Method in class rx.observers.TestObserver
Deprecated.
Get the Notifications representing each time this observer was notified of sequence completion via TestObserver.onCompleted(), as a List.
getOnCompletedEvents() - Method in class rx.observers.TestSubscriber
Deprecated.
getOnComputationScheduler() - Static method in class rx.plugins.RxJavaHooks
Returns the current computation scheduler hook function or null if it is set to the default pass-through.
getOnError() - Static method in class rx.plugins.RxJavaHooks
Returns the current global error handler hook action or null if it is set to the default one that signals errors to the current threads UncaughtExceptionHandler.
getOnErrorEvents() - Method in interface rx.observers.AssertableSubscriber
Returns a list of received onError signals.
getOnErrorEvents() - Method in class rx.observers.TestObserver
Deprecated.
Get the Throwables this observer was notified of via TestObserver.onError(java.lang.Throwable) as a List.
getOnErrorEvents() - Method in class rx.observers.TestSubscriber
Returns the Throwables this Subscriber was notified of via TestSubscriber.onError(java.lang.Throwable) as a List.
getOnGenericScheduledExecutorService() - Static method in class rx.plugins.RxJavaHooks
Returns the current factory for creating ScheduledExecutorServices in GenericScheduledExecutorService utility.
getOnIOScheduler() - Static method in class rx.plugins.RxJavaHooks
Returns the current io scheduler hook function or null if it is set to the default pass-through.
getOnNewThreadScheduler() - Static method in class rx.plugins.RxJavaHooks
Returns the current new thread scheduler hook function or null if it is set to the default pass-through.
getOnNextEvents() - Method in interface rx.observers.AssertableSubscriber
Returns the list of received onNext events.
getOnNextEvents() - Method in class rx.observers.TestObserver
Deprecated.
Get the sequence of items observed by this observer, as an ordered List.
getOnNextEvents() - Method in class rx.observers.TestSubscriber
Returns the sequence of items observed by this Subscriber, as an ordered List.
getOnObservableCreate() - Static method in class rx.plugins.RxJavaHooks
Returns the current Observable onCreate hook function or null if it is set to the default pass-through.
getOnObservableLift() - Static method in class rx.plugins.RxJavaHooks
Returns the current Observable onLift hook function or null if it is set to the default pass-through.
getOnObservableReturn() - Static method in class rx.plugins.RxJavaHooks
Returns the current Observable onReturn hook function or null if it is set to the default pass-through.
getOnObservableStart() - Static method in class rx.plugins.RxJavaHooks
Returns the current Observable onStart hook function or null if it is set to the default pass-through.
getOnObservableSubscribeError() - Static method in class rx.plugins.RxJavaHooks
Returns the current Observable onSubscribeError hook function or null if it is set to the default pass-through.
getOnScheduleAction() - Static method in class rx.plugins.RxJavaHooks
Returns the current schedule action hook function or null if it is set to the default pass-through.
getOnSingleCreate() - Static method in class rx.plugins.RxJavaHooks
Returns the current Single onCreate hook function or null if it is set to the default pass-through.
getOnSingleLift() - Static method in class rx.plugins.RxJavaHooks
Returns the current Single onLift hook function or null if it is set to the default pass-through.
getOnSingleReturn() - Static method in class rx.plugins.RxJavaHooks
Returns the current Single onReturn hook function or null if it is set to the default pass-through.
getOnSingleStart() - Static method in class rx.plugins.RxJavaHooks
Returns the current Single onStart hook function or null if it is set to the default pass-through.
getOnSingleSubscribeError() - Static method in class rx.plugins.RxJavaHooks
Returns the current Single onSubscribeError hook function or null if it is set to the default pass-through.
getSchedulersHook() - Method in class rx.plugins.RxJavaPlugins
Retrieves the instance of RxJavaSchedulersHook to use based on order of precedence as defined in the RxJavaPlugins class header.
getSingleExecutionHook() - Method in class rx.plugins.RxJavaPlugins
Retrieves the instance of RxJavaSingleExecutionHook to use based on order of precedence as defined in RxJavaPlugins class header.
getThrowable() - Method in class rx.Notification
Retrieves the exception associated with this (onError) notification.
getThrowable() - Method in class rx.subjects.AsyncSubject
Returns the Throwable that terminated the Subject.
getThrowable() - Method in class rx.subjects.BehaviorSubject
Returns the Throwable that terminated the Subject.
getThrowable() - Method in class rx.subjects.PublishSubject
Returns the Throwable that terminated the Subject.
getThrowable() - Method in class rx.subjects.ReplaySubject
Returns the Throwable that terminated the Subject.
getTimestampMillis() - Method in class rx.schedulers.Timestamped
Returns the timestamp, expressed in milliseconds.
getValue() - Method in exception rx.exceptions.OnErrorThrowable
Get the value associated with this OnErrorThrowable
getValue() - Method in exception rx.exceptions.OnErrorThrowable.OnNextValue
Retrieve the item that the Observable was trying to emit at the time this exception occurred.
getValue() - Method in class rx.Notification
Retrieves the item associated with this (onNext) notification.
getValue() - Method in class rx.schedulers.TimeInterval
Returns the item that was emitted by the Observable after this time interval.
getValue() - Method in class rx.schedulers.Timestamped
Returns the value embedded in the Timestamped object.
getValue() - Method in class rx.subjects.AsyncSubject
Returns the current value of the Subject if there is such a value and the subject hasn't terminated with an exception.
getValue() - Method in class rx.subjects.BehaviorSubject
Returns the current value of the Subject if there is such a value and the subject hasn't terminated yet.
getValue() - Method in class rx.subjects.ReplaySubject
 
getValueCount() - Method in interface rx.observers.AssertableSubscriber
Returns the number of onNext signals received by this Observer in a thread-safe manner; one can read up to this number of elements from the List returned by AssertableSubscriber.getOnNextEvents().
getValueCount() - Method in class rx.observers.TestSubscriber
Returns the committed number of onNext elements that are safe to be read from TestSubscriber.getOnNextEvents() other threads.
getValues(T[]) - Method in class rx.subjects.BehaviorSubject
Returns a snapshot of the currently buffered non-terminal events into the provided a array or creates a new array if it has not enough capacity.
getValues() - Method in class rx.subjects.BehaviorSubject
Returns a snapshot of the currently buffered non-terminal events.
getValues(T[]) - Method in class rx.subjects.ReplaySubject
Returns a snapshot of the currently buffered non-terminal events into the provided a array or creates a new array if it has not enough capacity.
getValues() - Method in class rx.subjects.ReplaySubject
Returns a snapshot of the currently buffered non-terminal events.
groupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>) - Method in class rx.Observable
Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as GroupedObservables.
groupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>, Func1<Action1<K>, Map<K, Object>>) - Method in class rx.Observable
Deprecated.
since 1.3.7, use Observable.groupBy(Func1, Func1, int, boolean, Func1) instead which uses much less memory. Please take note of the usage difference involving the evicting action which now expects the value from the map instead of the key.
groupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>, int, boolean, Func1<Action1<Object>, Map<K, Object>>) - Method in class rx.Observable
Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as GroupedObservables.
groupBy(Func1<? super T, ? extends K>) - Method in class rx.Observable
Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as GroupedObservables.
GroupedObservable<K,T> - Class in rx.observables
An Observable that has been grouped by key, the value of which can be obtained with GroupedObservable.getKey().
GroupedObservable(K, Observable.OnSubscribe<T>) - Constructor for class rx.observables.GroupedObservable
 
groupJoin(Observable<T2>, Func1<? super T, ? extends Observable<D1>>, Func1<? super T2, ? extends Observable<D2>>, Func2<? super T, ? super Observable<T2>, ? extends R>) - Method in class rx.Observable
Returns an Observable that correlates two Observables when they overlap in time and groups the results.

H

handleError(Throwable) - Method in class rx.plugins.RxJavaErrorHandler
Deprecated.
handleOnNextValueRendering(Object) - Method in class rx.plugins.RxJavaErrorHandler
Receives items causing OnErrorThrowable.OnNextValue and gives a chance to choose the String representation of the item in the OnNextValue stacktrace rendering.
hasAnyValue() - Method in class rx.subjects.ReplaySubject
 
hasCompleted() - Method in class rx.subjects.AsyncSubject
Check if the Subject has terminated normally.
hasCompleted() - Method in class rx.subjects.BehaviorSubject
Check if the Subject has terminated normally.
hasCompleted() - Method in class rx.subjects.PublishSubject
Check if the Subject has terminated normally.
hasCompleted() - Method in class rx.subjects.ReplaySubject
Check if the Subject has terminated normally.
hashCode() - Method in class rx.Notification
 
hashCode() - Method in class rx.schedulers.TimeInterval
 
hashCode() - Method in class rx.schedulers.Timestamped
 
hasObservers() - Method in class rx.subjects.AsyncSubject
 
hasObservers() - Method in class rx.subjects.BehaviorSubject
 
hasObservers() - Method in class rx.subjects.PublishSubject
 
hasObservers() - Method in class rx.subjects.ReplaySubject
 
hasObservers() - Method in class rx.subjects.SerializedSubject
 
hasObservers() - Method in class rx.subjects.Subject
Indicates whether the Subject has Observers subscribed to it.
hasObservers() - Method in class rx.subjects.TestSubject
 
hasObservers() - Method in class rx.subjects.UnicastSubject
 
hasSubscriptions() - Method in class rx.subscriptions.CompositeSubscription
Returns true if this composite is not unsubscribed and contains subscriptions.
hasThrowable() - Method in class rx.Notification
Indicates whether this notification has an exception associated with it.
hasThrowable() - Method in class rx.subjects.AsyncSubject
Check if the Subject has terminated with an exception.
hasThrowable() - Method in class rx.subjects.BehaviorSubject
Check if the Subject has terminated with an exception.
hasThrowable() - Method in class rx.subjects.PublishSubject
Check if the Subject has terminated with an exception.
hasThrowable() - Method in class rx.subjects.ReplaySubject
Check if the Subject has terminated with an exception.
hasValue() - Method in class rx.Notification
Indicates whether this notification has an item associated with it.
hasValue() - Method in class rx.subjects.AsyncSubject
Check if the Subject has a value.
hasValue() - Method in class rx.subjects.BehaviorSubject
Check if the Subject has a value.
hasValue() - Method in class rx.subjects.ReplaySubject
 

I

ignoreElements() - Method in class rx.Observable
Ignores all items emitted by the source Observable and only calls onCompleted or onError.
immediate() - Static method in class rx.schedulers.Schedulers
Creates and returns a Scheduler that executes work immediately on the current thread.
ImmediateScheduler - Class in rx.schedulers
Deprecated.
This type was never publicly instantiable. Use Schedulers.immediate().
interval(long, TimeUnit) - Static method in class rx.Observable
Returns an Observable that emits a sequential number every specified interval of time.
interval(long, TimeUnit, Scheduler) - Static method in class rx.Observable
Returns an Observable that emits a sequential number every specified interval of time, on a specified Scheduler.
interval(long, long, TimeUnit) - Static method in class rx.Observable
Returns an Observable that emits a 0L after the initialDelay and ever increasing numbers after each period of time thereafter.
interval(long, long, TimeUnit, Scheduler) - Static method in class rx.Observable
Returns an Observable that emits a 0L after the initialDelay and ever increasing numbers after each period of time thereafter, on a specified Scheduler.
io() - Static method in class rx.schedulers.Schedulers
Creates and returns a Scheduler intended for IO-bound work.
isEmpty() - Method in class rx.Observable
Returns an Observable that emits true if the source Observable is empty, otherwise false.
isLockdown() - Static method in class rx.plugins.RxJavaHooks
Returns true if the hooks can no longer be changed.
isOnCompleted() - Method in class rx.Notification
Indicates whether this notification represents an onCompleted event.
isOnError() - Method in class rx.Notification
Indicates whether this notification represents an onError event.
isOnNext() - Method in class rx.Notification
Indicates whether this notification represents an onNext event.
isUnsubscribed() - Method in interface rx.observers.AssertableSubscriber
 
isUnsubscribed() - Method in class rx.observers.AsyncCompletableSubscriber
 
isUnsubscribed() - Method in class rx.observers.SafeCompletableSubscriber
 
isUnsubscribed() - Method in class rx.SingleSubscriber
Indicates whether this Subscriber has unsubscribed from its list of subscriptions.
isUnsubscribed() - Method in class rx.Subscriber
Indicates whether this Subscriber has unsubscribed from its list of subscriptions.
isUnsubscribed() - Method in interface rx.Subscription
Indicates whether this Subscription is currently unsubscribed.
isUnsubscribed() - Method in class rx.subscriptions.BooleanSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.CompositeSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.MultipleAssignmentSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.RefCountSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.SerialSubscription
 
isValueNull() - Method in exception rx.exceptions.OnErrorThrowable
Indicates whether or not there is a value associated with this OnErrorThrowable

J

join(Observable<TRight>, Func1<T, Observable<TLeftDuration>>, Func1<TRight, Observable<TRightDuration>>, Func2<T, TRight, R>) - Method in class rx.Observable
Correlates the items emitted by two Observables based on overlapping durations.
just(T) - Static method in class rx.Observable
Returns an Observable that emits a single item and then completes.
just(T, T) - Static method in class rx.Observable
Converts two items into an Observable that emits those items.
just(T, T, T) - Static method in class rx.Observable
Converts three items into an Observable that emits those items.
just(T, T, T, T) - Static method in class rx.Observable
Converts four items into an Observable that emits those items.
just(T, T, T, T, T) - Static method in class rx.Observable
Converts five items into an Observable that emits those items.
just(T, T, T, T, T, T) - Static method in class rx.Observable
Converts six items into an Observable that emits those items.
just(T, T, T, T, T, T, T) - Static method in class rx.Observable
Converts seven items into an Observable that emits those items.
just(T, T, T, T, T, T, T, T) - Static method in class rx.Observable
Converts eight items into an Observable that emits those items.
just(T, T, T, T, T, T, T, T, T) - Static method in class rx.Observable
Converts nine items into an Observable that emits those items.
just(T, T, T, T, T, T, T, T, T, T) - Static method in class rx.Observable
Converts ten items into an Observable that emits those items.
just(T) - Static method in class rx.Single
Returns a Single that emits a specified item.

L

last() - Method in class rx.Observable
Returns an Observable that emits the last item emitted by the source Observable or notifies observers of a NoSuchElementException if the source Observable is empty.
last(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits only the last item emitted by the source Observable that satisfies a given condition, or notifies of a NoSuchElementException if no such items are emitted.
last() - Method in class rx.observables.BlockingObservable
Returns the last item emitted by this BlockingObservable, or throws NoSuchElementException if this BlockingObservable emits no items.
last(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the last item emitted by this BlockingObservable that matches a predicate, or throws NoSuchElementException if it emits no such items.
lastOrDefault(T) - Method in class rx.Observable
Returns an Observable that emits only the last item emitted by the source Observable, or a default item if the source Observable completes without emitting any items.
lastOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits only the last item emitted by the source Observable that satisfies a specified condition, or a default item if no such item is emitted by the source Observable.
lastOrDefault(T) - Method in class rx.observables.BlockingObservable
Returns the last item emitted by this BlockingObservable, or a default value if it emits no items.
lastOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the last item emitted by this BlockingObservable that matches a predicate, or a default value if it emits no such items.
latest() - Method in class rx.observables.BlockingObservable
Returns an Iterable that returns the latest item emitted by this BlockingObservable, waiting if necessary for one to become available.
lift(Completable.Operator) - Method in class rx.Completable
Lifts a CompletableSubscriber transformation into the chain of Completables.
lift(Observable.Operator<? extends R, ? super T>) - Method in class rx.Observable
This method requires advanced knowledge about building operators; please consider other standard composition methods first; Lifts a function to the current Observable and returns a new Observable that when subscribed to will pass the values of the current Observable through the Operator function.
lift(Observable.Operator<? extends R, ? super T>) - Method in class rx.Single
Lifts a function to the current Single and returns a new Single that when subscribed to will pass the values of the current Single through the Operator function.
limit(int) - Method in class rx.Observable
Returns an Observable that emits only the first count items emitted by the source Observable.
lockdown() - Static method in class rx.plugins.RxJavaHooks
Prevents changing the hooks.

M

map(Func1<? super T, ? extends R>) - Method in class rx.Observable
Returns an Observable that applies a specified function to each item emitted by the source Observable and emits the results of these function applications.
map(Func1<? super T, ? extends R>) - Method in class rx.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 rx.Observable
Returns an Observable that represents all of the emissions and notifications from the source Observable into emissions marked with their original types within Notification objects.
mayAttemptDrop() - Method in interface rx.BackpressureOverflow.Strategy
Whether the Backpressure manager should attempt to drop the oldest item, or simply drop the item currently causing backpressure.
merge(Completable...) - Static method in class rx.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(Iterable<? extends Completable>) - Static method in class rx.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(Observable<? extends Completable>) - Static method in class rx.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(Observable<? extends Completable>, int) - Static method in class rx.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 Observable<? extends T>>) - Static method in class rx.Observable
Flattens an Iterable of Observables into one Observable, without any transformation.
merge(Iterable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
Flattens an Iterable of Observables into one Observable, without any transformation, while limiting the number of concurrent subscriptions to these Observables.
merge(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Flattens an Observable that emits Observables into a single Observable that emits the items emitted by those Observables, without any transformation.
merge(Observable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
Flattens an Observable that emits Observables into a single Observable that emits the items emitted by those Observables, without any transformation, while limiting the maximum number of concurrent subscriptions to these Observables.
merge(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens two Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens three Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens four Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens five Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens six Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens seven Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens eight Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens nine Observables into a single Observable, without any transformation.
merge(Observable<? extends T>[]) - Static method in class rx.Observable
Flattens an Array of Observables into one Observable, without any transformation.
merge(Observable<? extends T>[], int) - Static method in class rx.Observable
Flattens an Array of Observables into one Observable, without any transformation, while limiting the number of concurrent subscriptions to these Observables.
merge(Single<? extends Single<? extends T>>) - Static method in class rx.Single
Flattens a Single that emits a Single into a single Single that emits the item emitted by the nested Single, without any transformation.
merge(Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Flattens two Singles into a single Observable, without any transformation.
merge(Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Flattens three Singles into a single Observable, without any transformation.
merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Flattens four Singles into a single Observable, without any transformation.
merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Flattens five Singles into a single Observable, without any transformation.
merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Flattens six Singles into a single Observable, without any transformation.
merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Flattens seven Singles into a single Observable, without any transformation.
merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Flattens eight Singles into a single Observable, without any transformation.
merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
Flattens nine Singles into a single Observable, without any transformation.
merge(Observable<? extends Single<? extends T>>) - Static method in class rx.Single
Merges all Singles emitted by the Observable and runs them together until the source Observable and all inner Singles complete normally.
merge(Observable<? extends Single<? extends T>>, int) - Static method in class rx.Single
Merges the Singles emitted by the Observable and runs up to the given number of them together at a time, until the Observable and all inner Singles terminate.
merge0(Observable<? extends Completable>, int, boolean) - Static method in class rx.Completable
Returns a Completable instance that keeps subscriptions to a limited number of sources at once and completes only when all source Completables terminate in one way or another, combining any exceptions thrown by either the sources Observable or the inner Completable instances.
mergeDelayError(Completable...) - Static method in class rx.Completable
Returns a Completable 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.
mergeDelayError(Iterable<? extends Completable>) - Static method in class rx.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(Observable<? extends Completable>) - Static method in class rx.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(Observable<? extends Completable>, int) - Static method in class rx.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(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Flattens an Observable that emits Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
Flattens an Observable that emits Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these Observables.
mergeDelayError(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Flattens an Iterable of Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from each of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Iterable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
Flattens an Iterable of Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from each of the source Observables without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these Observables.
mergeDelayError(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens two Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from each of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens three Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens four Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens five Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens six Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens seven Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens eight Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens nine Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends Single<? extends T>>) - Static method in class rx.Single
Merges all Singles emitted by the Observable and runs them together, delaying errors from them and the Observable, until the source Observable and all inner Singles complete normally.
mergeDelayError(Observable<? extends Single<? extends T>>, int) - Static method in class rx.Single
Merges the Singles emitted by the Observable and runs up to the given number of them together at a time, delaying errors from them and the Observable, until the Observable and all inner Singles terminate.
mergeWith(Completable) - Method in class rx.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(Observable<? extends T>) - Method in class rx.Observable
Flattens this and another Observable into a single Observable, without any transformation.
mergeWith(Single<? extends T>) - Method in class rx.Single
Flattens this and another Single into a single Observable, without any transformation.
MissingBackpressureException - Exception in rx.exceptions
Represents an exception that indicates that a Subscriber or operator attempted to apply reactive pull backpressure to an Observable that does not implement it.
MissingBackpressureException() - Constructor for exception rx.exceptions.MissingBackpressureException
Constructs the exception without any custom message.
MissingBackpressureException(String) - Constructor for exception rx.exceptions.MissingBackpressureException
Constructs the exception with the given customized message.
mostRecent(T) - Method in class rx.observables.BlockingObservable
Returns an Iterable that always returns the item most recently emitted by this BlockingObservable.
MultipleAssignmentSubscription - Class in rx.subscriptions
Subscription that can be checked for status such as in a loop inside an Observable to exit the loop if unsubscribed.
MultipleAssignmentSubscription() - Constructor for class rx.subscriptions.MultipleAssignmentSubscription
 

N

nest() - Method in class rx.Observable
Converts the source Observable<T> into an Observable<Observable<T>> that emits the source Observable as its single emission.
never() - Static method in class rx.Completable
Returns a Completable that never calls onError or onComplete.
never() - Static method in class rx.Observable
Returns an Observable that never sends any items or notifications to an Observer.
newThread() - Static method in class rx.schedulers.Schedulers
Creates and returns a Scheduler that creates a new Thread for each unit of work.
NewThreadScheduler - Class in rx.schedulers
Deprecated.
This type was never publicly instantiable. Use Schedulers.newThread().
next(S, long, Observer<Observable<? extends T>>) - Method in class rx.observables.AsyncOnSubscribe
Called to produce data to the downstream subscribers.
next() - Method in class rx.observables.BlockingObservable
Returns an Iterable that blocks until this BlockingObservable emits another item, then returns that item.
next(S, Observer<? super T>) - Method in class rx.observables.SyncOnSubscribe
Called to produce data to the downstream subscribers.
Notification<T> - Class in rx
An object representing a notification sent to an Observable.
Notification.Kind - Enum in rx
Specifies the kind of the notification: an element, an error or a completion notification.
now() - Method in class rx.Scheduler
Gets the current time, in milliseconds, according to this Scheduler.
now() - Method in class rx.Scheduler.Worker
Gets the current time, in milliseconds, according to this Scheduler.
now() - Method in class rx.schedulers.TestScheduler
 

O

Observable<T> - Class in rx
The Observable class that implements the Reactive Pattern.
Observable(Observable.OnSubscribe<T>) - Constructor for class rx.Observable
Creates an Observable with a Function to execute when it is subscribed to.
Observable.OnSubscribe<T> - Interface in rx
Invoked when Observable.subscribe is called.
Observable.Operator<R,T> - Interface in rx
Operator function for lifting into an Observable.
Observable.Transformer<T,R> - Interface in rx
Function that receives the current Observable and should return another Observable, possibly with given element type, in exchange that will be subscribed to by the downstream operators and subscribers.
observeOn(Scheduler) - Method in class rx.Completable
Returns a Completable which emits the terminal events from the thread of the specified scheduler.
observeOn(Scheduler) - Method in class rx.Observable
Modifies an Observable to perform its emissions and notifications on a specified Scheduler, asynchronously with a bounded buffer of RxRingBuffer.SIZE slots.
observeOn(Scheduler, int) - Method in class rx.Observable
Modifies an Observable to perform its emissions and notifications on a specified Scheduler, asynchronously with a bounded buffer of configurable size.
observeOn(Scheduler, boolean) - Method in class rx.Observable
Modifies an Observable to perform its emissions and notifications on a specified Scheduler, asynchronously with a bounded buffer and optionally delays onError notifications.
observeOn(Scheduler, boolean, int) - Method in class rx.Observable
Modifies an Observable to perform its emissions and notifications on a specified Scheduler, asynchronously with a bounded buffer of configurable size and optionally delays onError notifications.
observeOn(Scheduler) - Method in class rx.Single
Modifies a Single to emit its item (or notify of its error) on a specified Scheduler, asynchronously.
Observer<T> - Interface in rx
Provides a mechanism for receiving push-based notifications.
Observers - Class in rx.observers
Helper methods and utilities for creating and working with Observer objects.
ofType(Class<R>) - Method in class rx.Observable
Filters the items emitted by an Observable, only emitting those of the specified type.
ON_OVERFLOW_DEFAULT - Static variable in class rx.BackpressureOverflow
By default, signal a MissingBackressureException due to lack of requests.
ON_OVERFLOW_DROP_LATEST - Static variable in class rx.BackpressureOverflow
Drop the latest value.
ON_OVERFLOW_DROP_OLDEST - Static variable in class rx.BackpressureOverflow
Drop the oldest value in the buffer.
ON_OVERFLOW_ERROR - Static variable in class rx.BackpressureOverflow
Signal a MissingBackressureException due to lack of requests.
onBackpressureBuffer() - Method in class rx.Observable
Instructs an Observable that is emitting items faster than its observer can consume them to buffer these items indefinitely until they can be emitted.
onBackpressureBuffer(long) - Method in class rx.Observable
Instructs an Observable that is emitting items faster than its observer can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureBuffer(long, Action0) - Method in class rx.Observable
Instructs an Observable that is emitting items faster than its observer can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureBuffer(long, Action0, BackpressureOverflow.Strategy) - Method in class rx.Observable
Instructs an Observable that is emitting items faster than its observer can consume them to buffer up to a given amount of items until they can be emitted.
onBackpressureDrop(Action1<? super T>) - Method in class rx.Observable
Instructs an Observable that is emitting items faster than its observer can consume them to discard, rather than emit, those items that its observer is not prepared to observe.
onBackpressureDrop() - Method in class rx.Observable
Instructs an Observable that is emitting items faster than its observer can consume them to discard, rather than emit, those items that its observer is not prepared to observe.
onBackpressureLatest() - Method in class rx.Observable
Instructs an Observable that is emitting items faster than its observer can consume them to hold onto the latest value and emit that on request.
onCompletableError(Throwable) - Static method in class rx.plugins.RxJavaHooks
Hook to call if the Completable.subscribe() crashes for some reason.
onCompletableLift(Completable.Operator) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the child subscriber would subscribe to an Operator.
onCompletableStart(Completable, Completable.OnSubscribe) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the child subscriber is subscribed to the OnSubscribe action.
onCompleted() - Method in interface rx.CompletableEmitter
Notifies the CompletableSubscriber that the Completable has finished sending push-based notifications.
onCompleted() - Method in interface rx.CompletableSubscriber
Called once the deferred computation completes normally.
onCompleted() - Method in interface rx.Observer
Notifies the Observer that the Observable has finished sending push-based notifications.
onCompleted() - Method in class rx.observers.SafeCompletableSubscriber
 
onCompleted() - Method in class rx.observers.SafeSubscriber
Notifies the Subscriber that the Observable has finished sending push-based notifications.
onCompleted() - Method in class rx.observers.SerializedObserver
 
onCompleted() - Method in class rx.observers.SerializedSubscriber
Notifies the Subscriber that the Observable has finished sending push-based notifications.
onCompleted() - Method in class rx.observers.TestObserver
Deprecated.
 
onCompleted() - Method in class rx.observers.TestSubscriber
Notifies the Subscriber that the Observable has finished sending push-based notifications.
onCompleted() - Method in class rx.subjects.AsyncSubject
 
onCompleted() - Method in class rx.subjects.BehaviorSubject
 
onCompleted() - Method in class rx.subjects.PublishSubject
 
onCompleted() - Method in class rx.subjects.ReplaySubject
 
onCompleted() - Method in class rx.subjects.SerializedSubject
 
onCompleted() - Method in class rx.subjects.TestSubject
Schedule a call to onCompleted on TestScheduler.
onCompleted(long) - Method in class rx.subjects.TestSubject
Schedule a call to onCompleted relative to "now()" +n milliseconds in the future.
onCompleted() - Method in class rx.subjects.UnicastSubject
 
OnCompletedFailedException - Exception in rx.exceptions
Represents an exception used to re-throw errors thrown from Observer.onCompleted().
OnCompletedFailedException(Throwable) - Constructor for exception rx.exceptions.OnCompletedFailedException
Wraps the Throwable before it is to be re-thrown as an OnCompletedFailedException.
OnCompletedFailedException(String, Throwable) - Constructor for exception rx.exceptions.OnCompletedFailedException
Customizes the Throwable with a custom message and wraps it before it is to be re-thrown as an OnCompletedFailedException.
onComputationScheduler(Scheduler) - Static method in class rx.plugins.RxJavaHooks
Hook to call when the Schedulers.computation() is called.
onCreate(Completable.OnSubscribe) - Method in class rx.plugins.RxJavaCompletableExecutionHook
Deprecated.
onCreate(Observable.OnSubscribe<T>) - Static method in class rx.plugins.RxJavaHooks
Hook to call when an Observable is created.
onCreate(Single.OnSubscribe<T>) - Static method in class rx.plugins.RxJavaHooks
Hook to call when a Single is created.
onCreate(Completable.OnSubscribe) - Static method in class rx.plugins.RxJavaHooks
Hook to call when a Completable is created.
onCreate(Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
Deprecated.
onCreate(Single.OnSubscribe<T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
Deprecated.
onError(Throwable) - Method in interface rx.CompletableEmitter
Notifies the CompletableSubscriber that the Completable has experienced an error condition.
onError(Throwable) - Method in interface rx.CompletableSubscriber
Called once if the deferred computation 'throws' an exception.
onError(Throwable) - Method in interface rx.Observer
Notifies the Observer that the Observable has experienced an error condition.
onError(Throwable) - Method in class rx.observers.SafeCompletableSubscriber
 
onError(Throwable) - Method in class rx.observers.SafeSubscriber
Notifies the Subscriber that the Observable has experienced an error condition.
onError(Throwable) - Method in class rx.observers.SerializedObserver
 
onError(Throwable) - Method in class rx.observers.SerializedSubscriber
Notifies the Subscriber that the Observable has experienced an error condition.
onError(Throwable) - Method in class rx.observers.TestObserver
Deprecated.
 
onError(Throwable) - Method in class rx.observers.TestSubscriber
Notifies the Subscriber that the Observable has experienced an error condition.
onError(Throwable) - Static method in class rx.plugins.RxJavaHooks
Consume undeliverable Throwables (acts as a global catch).
onError(Throwable) - Method in interface rx.SingleEmitter
Notifies the SingleSubscriber that the Single has experienced an error condition.
onError(Throwable) - Method in class rx.SingleSubscriber
Notifies the SingleSubscriber that the Single has experienced an error condition.
onError(Throwable) - Method in class rx.subjects.AsyncSubject
 
onError(Throwable) - Method in class rx.subjects.BehaviorSubject
 
onError(Throwable) - Method in class rx.subjects.PublishSubject
 
onError(Throwable) - Method in class rx.subjects.ReplaySubject
 
onError(Throwable) - Method in class rx.subjects.SerializedSubject
 
onError(Throwable) - Method in class rx.subjects.TestSubject
Schedule a call to onError on TestScheduler.
onError(Throwable, long) - Method in class rx.subjects.TestSubject
Schedule a call to onError relative to "now()" +n milliseconds in the future.
onError(Throwable) - Method in class rx.subjects.UnicastSubject
 
onErrorComplete() - Method in class rx.Completable
Returns a Completable instance that if this Completable emits an error, it will emit an onComplete and swallow the throwable.
onErrorComplete(Func1<? super Throwable, Boolean>) - Method in class rx.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.
OnErrorFailedException - Exception in rx.exceptions
Represents an exception used to re-throw errors thrown from Observer.onError(Throwable).
OnErrorFailedException(String, Throwable) - Constructor for exception rx.exceptions.OnErrorFailedException
Customizes the Throwable with a custom message and wraps it before it is to be re-thrown as an OnErrorFailedException.
OnErrorFailedException(Throwable) - Constructor for exception rx.exceptions.OnErrorFailedException
Wraps the Throwable before it is to be re-thrown as an OnErrorFailedException.
OnErrorNotImplementedException - Exception in rx.exceptions
Represents an exception used to re-throw Observer.onError(Throwable) when an implementation doesn't exist.
OnErrorNotImplementedException(String, Throwable) - Constructor for exception rx.exceptions.OnErrorNotImplementedException
Customizes the Throwable with a custom message and wraps it before it is to be re-thrown as an OnErrorNotImplementedException.
OnErrorNotImplementedException(Throwable) - Constructor for exception rx.exceptions.OnErrorNotImplementedException
Wraps the Throwable before it is to be re-thrown as an OnErrorNotImplementedException.
onErrorResumeNext(Func1<? super Throwable, ? extends Completable>) - Method in class rx.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(Func1<? super Throwable, ? extends Observable<? extends T>>) - Method in class rx.Observable
Instructs an Observable to pass control to another Observable rather than invoking onError if it encounters an error.
onErrorResumeNext(Observable<? extends T>) - Method in class rx.Observable
Instructs an Observable to pass control to another Observable rather than invoking onError if it encounters an error.
onErrorResumeNext(Single<? extends T>) - Method in class rx.Single
Instructs a Single to pass control to another Single rather than invoking Observer.onError(Throwable) if it encounters an error.
onErrorResumeNext(Func1<Throwable, ? extends Single<? extends T>>) - Method in class rx.Single
Instructs a Single to pass control to another Single rather than invoking Observer.onError(Throwable) if it encounters an error.
onErrorReturn(Func1<? super Throwable, ? extends T>) - Method in class rx.Observable
Instructs an Observable to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturn(Func1<Throwable, ? extends T>) - Method in class rx.Single
Instructs a Single to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
OnErrorThrowable - Exception in rx.exceptions
Represents a Throwable that an Observable might notify its subscribers of, but that then can be handled by an operator that is designed to recover from or react appropriately to such an error.
OnErrorThrowable.OnNextValue - Exception in rx.exceptions
Represents an exception that was encountered while trying to emit an item from an Observable, and tries to preserve that item for future use and/or reporting.
onExceptionResumeNext(Observable<? extends T>) - Method in class rx.Observable
Instructs an Observable to pass control to another Observable rather than invoking onError if it encounters an Exception.
onIOScheduler(Scheduler) - Static method in class rx.plugins.RxJavaHooks
Hook to call when the Schedulers.io() is called.
onLift(Completable.Operator) - Method in class rx.plugins.RxJavaCompletableExecutionHook
Deprecated.
onLift(Observable.Operator<? extends R, ? super T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
Deprecated.
onLift(Observable.Operator<? extends R, ? super T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
Deprecated.
onNewThreadScheduler(Scheduler) - Static method in class rx.plugins.RxJavaHooks
Hook to call when the Schedulers.newThread() is called.
onNext(T) - Method in interface rx.Observer
Provides the Observer with a new item to observe.
onNext(T) - Method in class rx.observers.SafeSubscriber
Provides the Subscriber with a new item to observe.
onNext(T) - Method in class rx.observers.SerializedObserver
 
onNext(T) - Method in class rx.observers.SerializedSubscriber
Provides the Subscriber with a new item to observe.
onNext(T) - Method in class rx.observers.TestObserver
Deprecated.
 
onNext(T) - Method in class rx.observers.TestSubscriber
Provides the Subscriber with a new item to observe.
onNext(T) - Method in class rx.subjects.AsyncSubject
 
onNext(T) - Method in class rx.subjects.BehaviorSubject
 
onNext(T) - Method in class rx.subjects.PublishSubject
 
onNext(T) - Method in class rx.subjects.ReplaySubject
 
onNext(T) - Method in class rx.subjects.SerializedSubject
 
onNext(T) - Method in class rx.subjects.TestSubject
Schedule a call to onNext on TestScheduler.
onNext(T, long) - Method in class rx.subjects.TestSubject
Schedule a call to onNext relative to "now()" +n milliseconds in the future.
onNext(T) - Method in class rx.subjects.UnicastSubject
 
OnNextValue(Object) - Constructor for exception rx.exceptions.OnErrorThrowable.OnNextValue
Create an OnNextValue exception and include in its error message a string representation of the item that was intended to be emitted at the time the exception was handled.
onObservableError(Throwable) - Static method in class rx.plugins.RxJavaHooks
Hook to call if the Observable.subscribe() crashes for some reason.
onObservableLift(Observable.Operator<R, T>) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the child subscriber would subscribe to an Operator.
onObservableReturn(Subscription) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the Observable.subscribe() method is about to return a Subscription.
onObservableStart(Observable<T>, Observable.OnSubscribe<T>) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the child subscriber is subscribed to the OnSubscribe action.
onSchedule(Action0) - Method in class rx.plugins.RxJavaSchedulersHook
Deprecated.
onScheduledAction(Action0) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the action is scheduled, allows decorating the original action.
onSingleError(Throwable) - Static method in class rx.plugins.RxJavaHooks
Hook to call if the Single.subscribe() crashes for some reason.
onSingleLift(Observable.Operator<R, T>) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the child subscriber would subscribe to an Operator.
onSingleReturn(Subscription) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the Single.subscribe() method is about to return a Subscription.
onSingleStart(Single<T>, Single.OnSubscribe<T>) - Static method in class rx.plugins.RxJavaHooks
Hook to call before the child subscriber is subscribed to the OnSubscribe action.
onStart() - Method in interface rx.observers.AssertableSubscriber
Allows manually calling the onStart method of the underlying Subscriber.
onStart() - Method in class rx.observers.AsyncCompletableSubscriber
Called before the first onSubscribe() call succeeds.
onStart() - Method in class rx.Subscriber
This method is invoked when the Subscriber and Observable have been connected but the Observable has not yet begun to emit items or send notifications to the Subscriber.
onSubscribe(Subscription) - Method in interface rx.CompletableSubscriber
Called once by the Completable to set a Subscription on this instance which then can be used to cancel the subscription at any time.
onSubscribe(Subscription) - Method in class rx.observers.AsyncCompletableSubscriber
 
onSubscribe(Subscription) - Method in class rx.observers.SafeCompletableSubscriber
 
onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaCompletableExecutionHook
Deprecated.
onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaObservableExecutionHook
Deprecated.
onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaSingleExecutionHook
Deprecated.
onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaObservableExecutionHook
Deprecated.
onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaSingleExecutionHook
Deprecated.
onSubscribeStart(Completable, Completable.OnSubscribe) - Method in class rx.plugins.RxJavaCompletableExecutionHook
Deprecated.
onSubscribeStart(Observable<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
Deprecated.
onSubscribeStart(Single<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
Deprecated.
onSuccess(T) - Method in interface rx.SingleEmitter
Notifies the SingleSubscriber that the Single has completed successfully with the given value.
onSuccess(T) - Method in class rx.SingleSubscriber
Notifies the SingleSubscriber with a single item and that the Single has finished sending push-based notifications.
onTerminateDetach() - Method in class rx.Observable
Nulls out references to the upstream producer and downstream Subscriber if the sequence is terminated or downstream unsubscribes.
onUnsubscribe(S) - Method in class rx.observables.AsyncOnSubscribe
Clean up behavior that is executed after the downstream subscriber's subscription is unsubscribed.
onUnsubscribe(S) - Method in class rx.observables.SyncOnSubscribe
Clean up behavior that is executed after the downstream subscriber's subscription is unsubscribed.

P

perform(Action0) - Method in interface rx.observers.AssertableSubscriber
Performs an action given by the Action0 callback in a fluent manner.
printStackTrace() - Method in exception rx.exceptions.CompositeException
All of the following printStackTrace functionality is derived from JDK Throwable printStackTrace.
printStackTrace(PrintStream) - Method in exception rx.exceptions.CompositeException
 
printStackTrace(PrintWriter) - Method in exception rx.exceptions.CompositeException
 
Producer - Interface in rx
Interface that establishes a request-channel between an Observable and a Subscriber and allows the Subscriber to request a certain amount of items from the Observable (otherwise known as backpressure).
propagate(Throwable) - Static method in class rx.exceptions.Exceptions
Convenience method to throw a RuntimeException and Error directly or wrap any other exception type into a RuntimeException.
publish() - Method in class rx.Observable
Returns a ConnectableObservable, which is a variety of Observable that waits until its connect method is called before it begins emitting items to those Observers that have subscribed to it.
publish(Func1<? super Observable<T>, ? extends Observable<R>>) - Method in class rx.Observable
Returns an Observable that emits the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the underlying sequence.
PublishSubject<T> - Class in rx.subjects
Subject that, once an Observer has subscribed, emits all subsequently observed items to the subscriber.
PublishSubject(PublishSubject.PublishSubjectState<T>) - Constructor for class rx.subjects.PublishSubject
 

R

range(int, int) - Static method in class rx.Observable
Returns an Observable that emits a sequence of Integers within a specified range.
range(int, int, Scheduler) - Static method in class rx.Observable
Returns an Observable that emits a sequence of Integers within a specified range, on a specified Scheduler.
rebatchRequests(int) - Method in class rx.Observable
Requests n initially from the upstream and then 75% of n subsequently after 75% of n values have been emitted to the downstream.
reduce(Func2<T, T, T>) - Method in class rx.Observable
Returns an Observable that applies a specified accumulator function to the first item emitted by a source Observable, then feeds the result of that function along with the second item emitted by the source Observable into the same function, and so on until all items have been emitted by the source Observable, and emits the final result from the final call to your function as its sole item.
reduce(R, Func2<R, ? super T, R>) - Method in class rx.Observable
Returns an Observable that applies a specified accumulator function to the first item emitted by a source Observable and a specified seed value, then feeds the result of that function along with the second item emitted by an Observable into the same function, and so on until all items have been emitted by the source Observable, emitting the final result from the final call to your function as its sole item.
refCount() - Method in class rx.observables.ConnectableObservable
Returns an Observable that stays connected to this ConnectableObservable as long as there is at least one subscription to this ConnectableObservable.
RefCountSubscription - Class in rx.subscriptions
Keeps track of the sub-subscriptions and unsubscribes the underlying subscription once all sub-subscriptions have unsubscribed.
RefCountSubscription(Subscription) - Constructor for class rx.subscriptions.RefCountSubscription
Creates a RefCountSubscription by wrapping the given non-null Subscription.
registerCompletableExecutionHook(RxJavaCompletableExecutionHook) - Method in class rx.plugins.RxJavaPlugins
Register an RxJavaCompletableExecutionHook implementation as a global override of any injected or default implementations.
registerErrorHandler(RxJavaErrorHandler) - Method in class rx.plugins.RxJavaPlugins
Registers an RxJavaErrorHandler implementation as a global override of any injected or default implementations.
registerObservableExecutionHook(RxJavaObservableExecutionHook) - Method in class rx.plugins.RxJavaPlugins
Register an RxJavaObservableExecutionHook implementation as a global override of any injected or default implementations.
registerSchedulersHook(RxJavaSchedulersHook) - Method in class rx.plugins.RxJavaPlugins
Registers an RxJavaSchedulersHook implementation as a global override of any injected or default implementations.
registerSingleExecutionHook(RxJavaSingleExecutionHook) - Method in class rx.plugins.RxJavaPlugins
Register an RxJavaSingleExecutionHook implementation as a global override of any injected or default implementations.
remove(Subscription) - Method in class rx.subscriptions.CompositeSubscription
Removes a Subscription from this CompositeSubscription, and unsubscribes the Subscription.
render(Object) - Method in class rx.plugins.RxJavaErrorHandler
Override this method to provide rendering for specific types other than primitive types and null.
repeat() - Method in class rx.Completable
Returns a Completable that repeatedly subscribes to this Completable until cancelled.
repeat(long) - Method in class rx.Completable
Returns a Completable that subscribes repeatedly at most the given times to this Completable.
repeat() - Method in class rx.Observable
Returns an Observable that repeats the sequence of items emitted by the source Observable indefinitely.
repeat(Scheduler) - Method in class rx.Observable
Returns an Observable that repeats the sequence of items emitted by the source Observable indefinitely, on a particular Scheduler.
repeat(long) - Method in class rx.Observable
Returns an Observable that repeats the sequence of items emitted by the source Observable at most count times.
repeat(long, Scheduler) - Method in class rx.Observable
Returns an Observable that repeats the sequence of items emitted by the source Observable at most count times, on a particular Scheduler.
repeatWhen(Func1<? super Observable<? extends Void>, ? extends Observable<?>>) - Method in class rx.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(Func1<? super Observable<? extends Void>, ? extends Observable<?>>, Scheduler) - Method in class rx.Observable
Returns an Observable that emits the same values as the source Observable with the exception of an onCompleted.
repeatWhen(Func1<? super Observable<? extends Void>, ? extends Observable<?>>) - Method in class rx.Observable
Returns an Observable that emits the same values as the source Observable with the exception of an onCompleted.
replay() - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the underlying Observable that will replay all of its items and notifications to any future Observer.
replay(Func1<? super Observable<T>, ? extends Observable<R>>) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on the items emitted by a ConnectableObservable that shares a single subscription to the source Observable.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, int) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying bufferSize notifications.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying no more than bufferSize items that were emitted within a specified time window.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying no more than bufferSize items that were emitted within a specified time window.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, Scheduler) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying a maximum of bufferSize items.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying all items that were emitted within a specified time window.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying all items that were emitted within a specified time window.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, Scheduler) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable.
replay(int) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable that replays at most bufferSize items emitted by that Observable.
replay(int, long, TimeUnit) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and replays at most bufferSize items that were emitted during a specified time window.
replay(int, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and that replays a maximum of bufferSize items that are emitted within a specified time window.
replay(int, Scheduler) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and replays at most bufferSize items emitted by that Observable.
replay(long, TimeUnit) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and replays all items emitted by that Observable within a specified time window.
replay(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and replays all items emitted by that Observable within a specified time window.
replay(Scheduler) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable that will replay all of its items and notifications to any future Observer on the given Scheduler.
ReplaySubject<T> - Class in rx.subjects
Subject that buffers all items it observes and replays them to any Observer that subscribes.
request(long) - Method in interface rx.Producer
Request a certain maximum number of items from this Producer.
request(long) - Method in class rx.Subscriber
Request a certain maximum number of emitted items from the Observable this Subscriber is subscribed to.
requested() - Method in interface rx.Emitter
The current outstanding request amount.
requestMore(long) - Method in interface rx.observers.AssertableSubscriber
Requests the specified amount of items from upstream.
requestMore(long) - Method in class rx.observers.TestSubscriber
Allows calling the protected Subscriber.request(long) from unit tests.
reset() - Static method in class rx.plugins.RxJavaHooks
Reset all hook callbacks to those of the current RxJavaPlugins handlers.
reset() - Method in class rx.plugins.RxJavaPlugins
Reset RxJavaPlugins instance
reset() - Static method in class rx.schedulers.Schedulers
Resets the current Schedulers instance.
resetAssemblyTracking() - Static method in class rx.plugins.RxJavaHooks
Resets the assembly tracking hooks to their default delegates to RxJavaPlugins.
retry() - Method in class rx.Completable
Returns a Completable that retries this Completable as long as it emits an onError event.
retry(Func2<Integer, Throwable, Boolean>) - Method in class rx.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 rx.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() - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, resubscribing to it if it calls onError (infinite retry count).
retry(long) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, resubscribing to it if it calls onError up to a specified number of retries.
retry(Func2<Integer, Throwable, Boolean>) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, resubscribing to it if it calls onError and the predicate returns true for that specific exception and retry count.
retry() - Method in class rx.Single
Returns a Single that mirrors the source Single, resubscribing to it if it calls onError (infinite retry count).
retry(long) - Method in class rx.Single
Returns a Single that mirrors the source Single, resubscribing to it if it calls onError up to a specified number of retries.
retry(Func2<Integer, Throwable, Boolean>) - Method in class rx.Single
Returns a Single that mirrors the source Single, resubscribing to it if it calls onError and the predicate returns true for that specific exception and retry count.
retryWhen(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>>) - Method in class rx.Completable
Returns a Completable which given a Publisher and when this Completable emits an error, delivers that error through an Observable and the Publisher should return a value indicating a retry in response or a terminal event indicating a termination.
retryWhen(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>>) - Method in class rx.Observable
Returns an Observable that emits the same values as the source observable with the exception of an onError.
retryWhen(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>>, Scheduler) - Method in class rx.Observable
Returns an Observable that emits the same values as the source observable with the exception of an onError.
retryWhen(Func1<Observable<? extends Throwable>, ? extends Observable<?>>) - Method in class rx.Single
Returns a Single that emits the same values as the source Single with the exception of an onError.
rx - package rx
Base reactive classes: Observable, Single and Completable; base reactive consumers; other common base interfaces.
rx.annotations - package rx.annotations
Annotations for indicating experimental and beta operators, classes, methods, types or fields.
rx.exceptions - package rx.exceptions
Exception handling utilities, safe subscriber exception classes, lifecycle exception classes.
rx.functions - package rx.functions
Functional interfaces of functions and actions of arity 0 to 9 and related utility classes.
rx.observables - package rx.observables
Classes extending the Observable base reactive class, synchronous and asynchronous event generators.
rx.observers - package rx.observers
Default wrappers and implementations for the base reactive consumer classes and interfaces; utility classes for creating them from callbacks.
rx.plugins - package rx.plugins
Callback types and a central plugin handler class to hook into the lifecycle of the base reactive types and schedulers.
rx.schedulers - package rx.schedulers
Scheduler implementations, value+time record classes and the standard factory class to return standard RxJava schedulers or wrap any Executor-based (thread pool) instances.
rx.singles - package rx.singles
Classes extending the Single base reactive class.
rx.subjects - package rx.subjects
Classes extending the Observable base reactive class and implementing the Observer interface at the same time (aka hot Observables).
rx.subscriptions - package rx.subscriptions
Default implementations for Subscription-based resource management (Subscription container types) and utility classes to construct Subscriptions from callbacks and other types.
RxJavaCompletableExecutionHook - Class in rx.plugins
Abstract ExecutionHook with invocations at different lifecycle points of Completable execution with a default no-op implementation.
RxJavaCompletableExecutionHook() - Constructor for class rx.plugins.RxJavaCompletableExecutionHook
 
RxJavaErrorHandler - Class in rx.plugins
Abstract class for defining error handling logic in addition to the normal Observer.onError(Throwable) behavior.
RxJavaErrorHandler() - Constructor for class rx.plugins.RxJavaErrorHandler
 
RxJavaHooks - Class in rx.plugins
Utility class that holds hooks for various Observable, Single and Completable lifecycle-related points as well as Scheduler hooks.
RxJavaObservableExecutionHook - Class in rx.plugins
Abstract ExecutionHook with invocations at different lifecycle points of Observable execution with a default no-op implementation.
RxJavaObservableExecutionHook() - Constructor for class rx.plugins.RxJavaObservableExecutionHook
 
RxJavaPlugins - Class in rx.plugins
Registry for plugin implementations that allows global override and handles the retrieval of correct implementation based on order of precedence: plugin registered globally via register methods in this class plugin registered and retrieved using System.getProperty(String) (see get methods for property names) default implementation
RxJavaSchedulersHook - Class in rx.plugins
This plugin class provides 2 ways to customize Scheduler functionality 1.
RxJavaSchedulersHook() - Constructor for class rx.plugins.RxJavaSchedulersHook
 
RxJavaSingleExecutionHook - Class in rx.plugins
Abstract ExecutionHook with invocations at different lifecycle points of Single execution with a default no-op implementation.
RxJavaSingleExecutionHook() - Constructor for class rx.plugins.RxJavaSingleExecutionHook
 

S

SafeCompletableSubscriber - Class in rx.observers
Wraps another CompletableSubscriber and handles exceptions thrown from onError and onCompleted.
SafeCompletableSubscriber(CompletableSubscriber) - Constructor for class rx.observers.SafeCompletableSubscriber
 
SafeSubscriber<T> - Class in rx.observers
SafeSubscriber is a wrapper around Subscriber that ensures that the Subscriber complies with the Observable contract.
SafeSubscriber(Subscriber<? super T>) - Constructor for class rx.observers.SafeSubscriber
 
sample(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits the most recently emitted item (if any) emitted by the source Observable within periodic time intervals.
sample(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits the most recently emitted item (if any) emitted by the source Observable within periodic time intervals, where the intervals are defined on a particular Scheduler.
sample(Observable<U>) - Method in class rx.Observable
Returns an Observable that, when the specified sampler Observable emits an item or completes, emits the most recently emitted item (if any) emitted by the source Observable since the previous emission from the sampler Observable.
scan(Func2<T, T, T>) - Method in class rx.Observable
Returns an Observable that applies a specified accumulator function to the first item emitted by a source Observable, then feeds the result of that function along with the second item emitted by the source Observable into the same function, and so on until all items have been emitted by the source Observable, emitting the result of each of these iterations.
scan(R, Func2<R, ? super T, R>) - Method in class rx.Observable
Returns an Observable that applies a specified accumulator function to the first item emitted by a source Observable and a seed value, then feeds the result of that function along with the second item emitted by the source Observable into the same function, and so on until all items have been emitted by the source Observable, emitting the result of each of these iterations.
schedule(Action0) - Method in class rx.Scheduler.Worker
Schedules an Action for execution.
schedule(Action0, long, TimeUnit) - Method in class rx.Scheduler.Worker
Schedules an Action for execution at some point in the future.
schedulePeriodically(Action0, long, long, TimeUnit) - Method in class rx.Scheduler.Worker
Schedules a cancelable action to be executed periodically.
Scheduler - Class in rx
A Scheduler is an object that schedules units of work.
Scheduler() - Constructor for class rx.Scheduler
 
Scheduler.Worker - Class in rx
Sequential Scheduler for executing actions on a single thread or event loop.
Schedulers - Class in rx.schedulers
Static factory methods for creating Schedulers.
sequenceEqual(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits a Boolean value that indicates whether two Observable sequences are the same by comparing the items emitted by each Observable pairwise.
sequenceEqual(Observable<? extends T>, Observable<? extends T>, Func2<? super T, ? super T, Boolean>) - Static method in class rx.Observable
Returns an Observable that emits a Boolean value that indicates whether two Observable sequences are the same by comparing the items emitted by each Observable pairwise based on the results of a specified equality function.
serialize() - Method in class rx.Observable
Forces an Observable's emissions and notifications to be serialized and for it to obey the Observable contract in other ways.
SerializedObserver<T> - Class in rx.observers
SerializedObserver(Observer<? super T>) - Constructor for class rx.observers.SerializedObserver
 
SerializedSubject<T,R> - Class in rx.subjects
Wraps a Subject so that it is safe to call its various on methods from different threads.
SerializedSubject(Subject<T, R>) - Constructor for class rx.subjects.SerializedSubject
 
SerializedSubscriber<T> - Class in rx.observers
SerializedSubscriber(Subscriber<? super T>) - Constructor for class rx.observers.SerializedSubscriber
 
SerializedSubscriber(Subscriber<? super T>, boolean) - Constructor for class rx.observers.SerializedSubscriber
Constructor for wrapping and serializing a subscriber optionally sharing the same underlying subscription list.
SerialSubscription - Class in rx.subscriptions
Represents a subscription whose underlying subscription can be swapped for another subscription which causes the previous underlying subscription to be unsubscribed.
SerialSubscription() - Constructor for class rx.subscriptions.SerialSubscription
 
set(Subscription) - Method in class rx.subscriptions.MultipleAssignmentSubscription
Sets the underlying subscription.
set(Subscription) - Method in class rx.subscriptions.SerialSubscription
Sets the underlying subscription.
setCancellation(Cancellable) - Method in interface rx.CompletableEmitter
Sets a Cancellable on this emitter; any previous Subscription or Cancellation will be unsubscribed/cancelled.
setCancellation(Cancellable) - Method in interface rx.Emitter
Sets a Cancellable on this emitter; any previous Subscription or Cancellation will be unsubscribed/cancelled.
setCancellation(Cancellable) - Method in interface rx.SingleEmitter
Sets a Cancellable on this emitter; any previous Subscription or Cancellation will be unsubscribed/cancelled.
setOnCompletableCreate(Func1<Completable.OnSubscribe, Completable.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
Sets the Completable's onCreate hook function unless a lockdown is in effect.
setOnCompletableLift(Func1<Completable.Operator, Completable.Operator>) - Static method in class rx.plugins.RxJavaHooks
Sets a hook function that is called with an operator when a Completable operator built with lift() gets subscribed to.
setOnCompletableStart(Func2<Completable, Completable.OnSubscribe, Completable.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
Sets the hook function that is called when a subscriber subscribes to a Completable unless a lockdown is in effect.
setOnCompletableSubscribeError(Func1<Throwable, Throwable>) - Static method in class rx.plugins.RxJavaHooks
Sets a hook function that is called when the Completable.subscribe() call fails with an exception.
setOnComputationScheduler(Func1<Scheduler, Scheduler>) - Static method in class rx.plugins.RxJavaHooks
Sets the hook function for returning a scheduler when the Schedulers.computation() is called unless a lockdown is in effect.
setOnError(Action1<Throwable>) - Static method in class rx.plugins.RxJavaHooks
Sets the global error consumer action unless a lockdown is in effect.
setOnGenericScheduledExecutorService(Func0<? extends ScheduledExecutorService>) - Static method in class rx.plugins.RxJavaHooks
Sets the hook function for returning a ScheduledExecutorService used by the GenericScheduledExecutorService for background tasks.
setOnIOScheduler(Func1<Scheduler, Scheduler>) - Static method in class rx.plugins.RxJavaHooks
Sets the hook function for returning a scheduler when the Schedulers.io() is called unless a lockdown is in effect.
setOnNewThreadScheduler(Func1<Scheduler, Scheduler>) - Static method in class rx.plugins.RxJavaHooks
Sets the hook function for returning a scheduler when the Schedulers.newThread() is called unless a lockdown is in effect.
setOnObservableCreate(Func1<Observable.OnSubscribe, Observable.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
Sets the Observable onCreate hook function unless a lockdown is in effect.
setOnObservableLift(Func1<Observable.Operator, Observable.Operator>) - Static method in class rx.plugins.RxJavaHooks
Sets a hook function that is called with an operator when an Observable operator built with lift() gets subscribed to.
setOnObservableReturn(Func1<Subscription, Subscription>) - Static method in class rx.plugins.RxJavaHooks
Sets a hook function that is called when the Observable.subscribe() call is about to return a Subscription unless a lockdown is in effect.
setOnObservableStart(Func2<Observable, Observable.OnSubscribe, Observable.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
Sets the hook function that is called when a subscriber subscribes to a Observable unless a lockdown is in effect.
setOnObservableSubscribeError(Func1<Throwable, Throwable>) - Static method in class rx.plugins.RxJavaHooks
Sets a hook function that is called when the Observable.subscribe() call fails with an exception.
setOnScheduleAction(Func1<Action0, Action0>) - Static method in class rx.plugins.RxJavaHooks
Sets the hook function that is called before an action is scheduled, allowing decorating that function, unless a lockdown is in effect.
setOnSingleCreate(Func1<Single.OnSubscribe, Single.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
Sets the Single onCreate hook function unless a lockdown is in effect.
setOnSingleLift(Func1<Observable.Operator, Observable.Operator>) - Static method in class rx.plugins.RxJavaHooks
Sets a hook function that is called with an operator when an Single operator built with lift() gets subscribed to.
setOnSingleReturn(Func1<Subscription, Subscription>) - Static method in class rx.plugins.RxJavaHooks
Sets a hook function that is called when the Single.subscribe() call is about to return a Subscription unless a lockdown is in effect.
setOnSingleStart(Func2<Single, Single.OnSubscribe, Single.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
Sets the hook function that is called when a subscriber subscribes to a Single unless a lockdown is in effect.
setOnSingleSubscribeError(Func1<Throwable, Throwable>) - Static method in class rx.plugins.RxJavaHooks
Sets a hook function that is called when the Single.subscribe() call fails with an exception.
setProducer(Producer) - Method in interface rx.observers.AssertableSubscriber
Allows manually calling the setProducer method of the underlying Subscriber.
setProducer(Producer) - Method in class rx.Subscriber
If other subscriber is set (by calling constructor Subscriber.Subscriber(Subscriber) or Subscriber.Subscriber(Subscriber, boolean)) then this method calls setProducer on the other subscriber.
setSubscription(Subscription) - Method in interface rx.CompletableEmitter
Sets a Subscription on this emitter; any previous Subscription or Cancellation will be unsubscribed/cancelled.
setSubscription(Subscription) - Method in interface rx.Emitter
Sets a Subscription on this emitter; any previous Subscription or Cancellation will be unsubscribed/cancelled.
setSubscription(Subscription) - Method in interface rx.SingleEmitter
Sets a Subscription on this emitter; any previous Subscription or Cancellation will be unsubscribed/cancelled.
share() - Method in class rx.Observable
Returns a new Observable that multicasts (shares) the original Observable.
shutdown() - Static method in class rx.schedulers.Schedulers
Shuts down those standard Schedulers which support the SchedulerLifecycle interface.
single() - Method in class rx.Observable
Returns an Observable that emits the single item emitted by the source Observable, if that Observable emits only a single item.
single(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits the single item emitted by the source Observable that matches a specified predicate, if that Observable emits one such item.
single() - Method in class rx.observables.BlockingObservable
If this BlockingObservable completes after emitting a single item, return that item, otherwise throw a NoSuchElementException.
single(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
If this BlockingObservable completes after emitting a single item that matches a given predicate, return that item, otherwise throw a NoSuchElementException.
Single<T> - Class in rx
The Single class implements the Reactive Pattern for a single value response.
Single(Single.OnSubscribe<T>) - Constructor for class rx.Single
Creates a Single with a Function to execute when it is subscribed to (executed).
Single(Observable.OnSubscribe<T>) - Constructor for class rx.Single
Deprecated.
1.2.1: Not recommended, use Single.Single(OnSubscribe) to avoid wrapping and conversion between the Observable and Single protocols.
Single.OnSubscribe<T> - Interface in rx
Invoked when Single.execute is called.
Single.Transformer<T,R> - Interface in rx
Convenience type that allows a function to fluently transform a Single into another Single via Single.compose(rx.Single.Transformer<? super T, ? extends R>).
SingleEmitter<T> - Interface in rx
Abstraction over a SingleSubscriber that gets either an onSuccess or onError signal and allows registering an cancellation/unsubscription callback.
singleOrDefault(T) - Method in class rx.Observable
Returns an Observable that emits the single item emitted by the source Observable, if that Observable emits only a single item, or a default item if the source Observable emits no items.
singleOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits the single item emitted by the source Observable that matches a predicate, if that Observable emits only one such item, or a default item if the source Observable emits no such items.
singleOrDefault(T) - Method in class rx.observables.BlockingObservable
If this BlockingObservable completes after emitting a single item, return that item; if it emits more than one item, throw an IllegalArgumentException; if it emits no items, return a default value.
singleOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
If this BlockingObservable completes after emitting a single item that matches a predicate, return that item; if it emits more than one such item, throw an IllegalArgumentException; if it emits no items, return a default value.
SingleSubscriber<T> - Class in rx
Provides a mechanism for receiving push-based notifications.
SingleSubscriber() - Constructor for class rx.SingleSubscriber
 
size() - Method in class rx.subjects.ReplaySubject
Returns the current number of items (non-terminal events) available for replay.
skip(int) - Method in class rx.Observable
Returns an Observable that skips the first count items emitted by the source Observable and emits the remainder.
skip(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that skips values emitted by the source Observable before a specified time window elapses.
skip(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that skips values emitted by the source Observable before a specified time window on a specified Scheduler elapses.
skipLast(int) - Method in class rx.Observable
Returns an Observable that drops a specified number of items from the end of the sequence emitted by the source Observable.
skipLast(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that drops items emitted by the source Observable during a specified time window before the source completes.
skipLast(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that drops items emitted by the source Observable during a specified time window (defined on a specified scheduler) before the source completes.
skipUntil(Observable<U>) - Method in class rx.Observable
Returns an Observable that skips items emitted by the source Observable until a second Observable emits an item.
skipWhile(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that skips all items emitted by the source Observable 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 rx.Observable
Returns an Observable that emits the events emitted by source Observable, in a sorted order.
sorted(Func2<? super T, ? super T, Integer>) - Method in class rx.Observable
Returns an Observable that emits the events emitted by source Observable, in a sorted order based on a specified comparison function.
start() - Static method in class rx.schedulers.Schedulers
Starts those standard Schedulers which support the SchedulerLifecycle interface.
startWith(Completable) - Method in class rx.Completable
Returns a Completable which first runs the other Completable then this completable if the other completed normally.
startWith(Observable<T>) - Method in class rx.Completable
Returns an Observable which first delivers the events of the other Observable then runs this Completable.
startWith(Observable<T>) - Method in class rx.Observable
Returns an Observable that emits the items in a specified Observable before it begins to emit items emitted by the source Observable.
startWith(Iterable<T>) - Method in class rx.Observable
Returns an Observable that emits the items in a specified Iterable before it begins to emit items emitted by the source Observable.
startWith(T) - Method in class rx.Observable
Returns an Observable that emits a specified item before it begins to emit items emitted by the source Observable.
startWith(T, T) - Method in class rx.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
startWith(T, T, T) - Method in class rx.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
startWith(T, T, T, T) - Method in class rx.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
startWith(T, T, T, T, T) - Method in class rx.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
startWith(T, T, T, T, T, T) - Method in class rx.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
startWith(T, T, T, T, T, T, T) - Method in class rx.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
startWith(T, T, T, T, T, T, T, T) - Method in class rx.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
startWith(T, T, T, T, T, T, T, T, T) - Method in class rx.Observable
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
Subject<T,R> - Class in rx.subjects
Represents an object that is both an Observable and an Observer.
Subject(Observable.OnSubscribe<R>) - Constructor for class rx.subjects.Subject
 
subscribe() - Method in class rx.Completable
Subscribes to this Completable and returns a Subscription which can be used to cancel the subscription.
subscribe(Action0) - Method in class rx.Completable
Subscribes to this Completable and calls the given Action0 when this Completable completes normally.
subscribe(Action0, Action1<? super Throwable>) - Method in class rx.Completable
Subscribes to this Completable and calls back either the onError or onComplete functions.
subscribe(CompletableSubscriber) - Method in class rx.Completable
Subscribes the given CompletableSubscriber to this Completable instance and handles exceptions thrown by its onXXX methods.
subscribe(Subscriber<T>) - Method in class rx.Completable
Subscribes a regular Subscriber to this Completable instance which will receive only an onError or onComplete event and handles exceptions thrown by its onXXX methods.
subscribe() - Method in class rx.Observable
Subscribes to an Observable and ignores onNext and onCompleted emissions.
subscribe(Action1<? super T>) - Method in class rx.Observable
Subscribes to an Observable and provides a callback to handle the items it emits.
subscribe(Action1<? super T>, Action1<Throwable>) - Method in class rx.Observable
Subscribes to an Observable and provides callbacks to handle the items it emits and any error notification it issues.
subscribe(Action1<? super T>, Action1<Throwable>, Action0) - Method in class rx.Observable
Subscribes to an Observable and provides callbacks to handle the items it emits and any error or completion notification it issues.
subscribe(Observer<? super T>) - Method in class rx.Observable
Subscribes to an Observable and provides an Observer that implements functions to handle the items the Observable emits and any error or completion notification it issues.
subscribe(Subscriber<? super T>) - Method in class rx.Observable
Subscribes to an Observable and provides a Subscriber that implements functions to handle the items the Observable emits and any error or completion notification it issues.
subscribe() - Method in class rx.observables.BlockingObservable
Runs the source observable to a terminal event, ignoring any values and rethrowing any exception.
subscribe(Observer<? super T>) - Method in class rx.observables.BlockingObservable
Subscribes to the source and calls back the Observer methods on the current thread.
subscribe(Subscriber<? super T>) - Method in class rx.observables.BlockingObservable
Subscribes to the source and calls the Subscriber methods on the current thread.
subscribe(Action1<? super T>) - Method in class rx.observables.BlockingObservable
Subscribes to the source and calls the given action on the current thread and rethrows any exception wrapped into OnErrorNotImplementedException.
subscribe(Action1<? super T>, Action1<? super Throwable>) - Method in class rx.observables.BlockingObservable
Subscribes to the source and calls the given actions on the current thread.
subscribe(Action1<? super T>, Action1<? super Throwable>, Action0) - Method in class rx.observables.BlockingObservable
Subscribes to the source and calls the given actions on the current thread.
subscribe() - Method in class rx.Single
Subscribes to a Single but ignore its emission or notification.
subscribe(Action1<? super T>) - Method in class rx.Single
Subscribes to a Single and provides a callback to handle the item it emits.
subscribe(Action1<? super T>, Action1<Throwable>) - Method in class rx.Single
Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it issues.
subscribe(Observer<? super T>) - Method in class rx.Single
Subscribes an Observer to this single and returns a Subscription that allows unsubscription.
subscribe(Subscriber<? super T>) - Method in class rx.Single
Subscribes to a Single and provides a Subscriber that implements functions to handle the item the Single emits or any error notification it issues.
subscribe(SingleSubscriber<? super T>) - Method in class rx.Single
Subscribes to a Single and provides a SingleSubscriber that implements functions to handle the item the Single emits or any error notification it issues.
subscribeOn(Scheduler) - Method in class rx.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 rx.Observable
Asynchronously subscribes Observers to this Observable on the specified Scheduler.
subscribeOn(Scheduler, boolean) - Method in class rx.Observable
Asynchronously subscribes Observers to this Observable on the specified Scheduler and optionally reroutes requests from other threads to the same Scheduler thread.
subscribeOn(Scheduler) - Method in class rx.Single
Asynchronously subscribes subscribers to this Single on the specified Scheduler.
Subscriber<T> - Class in rx
Provides a mechanism for receiving push-based notifications from Observables, and permits manual unsubscribing from these Observables.
Subscriber() - Constructor for class rx.Subscriber
 
Subscriber(Subscriber<?>) - Constructor for class rx.Subscriber
Construct a Subscriber by using another Subscriber for backpressure and for holding the subscription list (when this.add(sub) is called this will in fact call subscriber.add(sub)).
Subscriber(Subscriber<?>, boolean) - Constructor for class rx.Subscriber
Construct a Subscriber by using another Subscriber for backpressure and optionally for holding the subscription list (if shareSubscriptions is true then when this.add(sub) is called this will in fact call subscriber.add(sub)).
Subscribers - Class in rx.observers
Helper methods and utilities for creating and working with Subscriber objects.
Subscription - Interface in rx
Subscription returns from Observable.subscribe(Subscriber) to allow unsubscribing.
Subscriptions - Class in rx.subscriptions
Helper methods and utilities for creating and working with Subscription objects
switchIfEmpty(Observable<? extends T>) - Method in class rx.Observable
Returns an Observable that emits the items emitted by the source Observable or the items of an alternate Observable if the source Observable is empty.
switchMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Returns a new Observable by applying a function that you supply to each item emitted by the source Observable that returns an Observable, and then emitting the items emitted by the most recently emitted of these Observables.
switchMapDelayError(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Returns a new Observable by applying a function that you supply to each item emitted by the source Observable that returns an Observable, and then emitting the items emitted by the most recently emitted of these Observables and delays any error until all Observables terminate.
switchOnNext(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Converts an Observable that emits Observables into an Observable that emits the items emitted by the most recently emitted of those Observables.
switchOnNextDelayError(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Converts an Observable that emits Observables into an Observable that emits the items emitted by the most recently emitted of those Observables and delays any exception until all Observables terminate.
SyncOnSubscribe<S,T> - Class in rx.observables
A utility class to create OnSubscribe<T> functions that responds correctly to back pressure requests from subscribers.
SyncOnSubscribe() - Constructor for class rx.observables.SyncOnSubscribe
 

T

take(int) - Method in class rx.Observable
Returns an Observable that emits only the first count items emitted by the source Observable.
take(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits those items emitted by source Observable before a specified time runs out.
take(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits those items emitted by source Observable before a specified time (on a specified Scheduler) runs out.
takeFirst(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits only the very first item emitted by the source Observable that satisfies a specified condition.
takeLast(int) - Method in class rx.Observable
Returns an Observable that emits at most the last count items emitted by the source Observable.
takeLast(int, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits at most a specified number of items from the source Observable that were emitted in a specified window of time before the Observable completed.
takeLast(int, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits at most a specified number of items from the source Observable that were emitted in a specified window of time before the Observable completed, where the timing information is provided by a given Scheduler.
takeLast(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits the items from the source Observable that were emitted in a specified window of time before the Observable completed.
takeLast(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits the items from the source Observable that were emitted in a specified window of time before the Observable completed, where the timing information is provided by a specified Scheduler.
takeLastBuffer(int) - Method in class rx.Observable
Returns an Observable that emits a single List containing at most the last count elements emitted by the source Observable.
takeLastBuffer(int, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits a single List containing at most count items from the source Observable that were emitted during a specified window of time before the source Observable completed.
takeLastBuffer(int, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits a single List containing at most count items from the source Observable that were emitted during a specified window of time (on a specified Scheduler) before the source Observable completed.
takeLastBuffer(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits a single List containing those items from the source Observable that were emitted during a specified window of time before the source Observable completed.
takeLastBuffer(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits a single List containing those items from the source Observable that were emitted during a specified window of time before the source Observable completed, where the timing information is provided by the given Scheduler.
takeUntil(Observable<? extends E>) - Method in class rx.Observable
Returns an Observable that emits the items emitted by the source Observable until a second Observable emits an item.
takeUntil(Func1<? super T, Boolean>) - Method in class rx.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(Completable) - Method in class rx.Single
Returns a Single that emits the item emitted by the source Single until a Completable terminates.
takeUntil(Observable<? extends E>) - Method in class rx.Single
Returns a Single that emits the item emitted by the source Single until an Observable emits an item.
takeUntil(Single<? extends E>) - Method in class rx.Single
Returns a Single that emits the item emitted by the source Single until a second Single emits an item.
takeWhile(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits items emitted by the source Observable so long as each item satisfied a specified condition, and then completes as soon as this condition is not satisfied.
test() - Method in class rx.Completable
Creates an AssertableSubscriber that requests Long.MAX_VALUE and subscribes it to this Observable.
test() - Method in class rx.Observable
Creates a AssertableSubscriber that requests Long.MAX_VALUE and subscribes it to this Observable.
test(long) - Method in class rx.Observable
Creates an AssertableSubscriber with the initial request amount and subscribes it to this Observable.
test() - Static method in class rx.schedulers.Schedulers
Creates and returns a TestScheduler, which is useful for debugging.
test() - Method in class rx.Single
Creates an AssertableSubscriber that requests Long.MAX_VALUE and subscribes it to this Observable.
TestObserver<T> - Class in rx.observers
Deprecated.
use the TestSubscriber instead.
TestObserver(Observer<T>) - Constructor for class rx.observers.TestObserver
Deprecated.
 
TestObserver() - Constructor for class rx.observers.TestObserver
Deprecated.
 
TestScheduler - Class in rx.schedulers
The TestScheduler is useful for debugging.
TestScheduler() - Constructor for class rx.schedulers.TestScheduler
 
TestSubject<T> - Class in rx.subjects
A variety of Subject that is useful for testing purposes.
TestSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>, TestScheduler) - Constructor for class rx.subjects.TestSubject
 
TestSubscriber<T> - Class in rx.observers
A TestSubscriber is a variety of Subscriber that you can use for unit testing, to perform assertions, inspect received events, or wrap a mocked Subscriber.
TestSubscriber(long) - Constructor for class rx.observers.TestSubscriber
Constructs a TestSubscriber with the initial request to be requested from upstream.
TestSubscriber(Observer<T>, long) - Constructor for class rx.observers.TestSubscriber
Constructs a TestSubscriber with the initial request to be requested from upstream and a delegate Observer to wrap.
TestSubscriber(Subscriber<T>) - Constructor for class rx.observers.TestSubscriber
Constructs a TestSubscriber which requests Long.MAX_VALUE and delegates events to the given Subscriber.
TestSubscriber(Observer<T>) - Constructor for class rx.observers.TestSubscriber
Constructs a TestSubscriber which requests Long.MAX_VALUE and delegates events to the given Observer.
TestSubscriber() - Constructor for class rx.observers.TestSubscriber
Constructs a TestSubscriber with an initial request of Long.MAX_VALUE and no delegation.
throttleFirst(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits only the first item emitted by the source Observable during sequential time windows of a specified duration.
throttleFirst(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits only the first item emitted by the source Observable during sequential time windows of a specified duration, where the windows are managed by a specified Scheduler.
throttleLast(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits only the last item emitted by the source Observable during sequential time windows of a specified duration.
throttleLast(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits only the last item emitted by the source Observable during sequential time windows of a specified duration, where the duration is governed by a specified Scheduler.
throttleWithTimeout(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that only emits those items emitted by the source Observable that are not followed by another emitted item within a specified time window.
throttleWithTimeout(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that only emits those items emitted by the source Observable that are not followed by another emitted item within a specified time window, where the time window is governed by a specified Scheduler.
throwIfAny(List<? extends Throwable>) - Static method in class rx.exceptions.Exceptions
Throws a single or multiple exceptions contained in the collection, wrapping it into CompositeException if necessary.
throwIfFatal(Throwable) - Static method in class rx.exceptions.Exceptions
Throws a particular Throwable only if it belongs to a set of "fatal" error varieties.
throwOrReport(Throwable, Observer<?>, Object) - Static method in class rx.exceptions.Exceptions
Forwards a fatal exception or reports it along with the value caused it to the given Observer.
throwOrReport(Throwable, SingleSubscriber<?>, Object) - Static method in class rx.exceptions.Exceptions
Forwards a fatal exception or reports it along with the value caused it to the given SingleSubscriber.
throwOrReport(Throwable, Observer<?>) - Static method in class rx.exceptions.Exceptions
Forwards a fatal exception or reports it to the given Observer.
throwOrReport(Throwable, SingleSubscriber<?>) - Static method in class rx.exceptions.Exceptions
Forwards a fatal exception or reports it to the given Observer.
timeInterval() - Method in class rx.Observable
Returns an Observable that emits records of the time interval between consecutive items emitted by the source Observable.
timeInterval(Scheduler) - Method in class rx.Observable
Returns an Observable that emits records of the time interval between consecutive items emitted by the source Observable, where this interval is computed on a specified Scheduler.
TimeInterval<T> - Class in rx.schedulers
A TimeInterval represents an item emitted by an Observable along with the amount of time that elapsed either since the emission of the previous item or (if there was no previous item) since the Observable was first subscribed to.
TimeInterval(long, T) - Constructor for class rx.schedulers.TimeInterval
Creates a TimeInterval object.
timeout(long, TimeUnit) - Method in class rx.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, Completable) - Method in class rx.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 rx.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, Completable) - Method in class rx.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(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, but notifies observers of a TimeoutException if either the first item emitted by the source Observable or any subsequent item doesn't arrive within time windows defined by other Observables.
timeout(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>, Observable<? extends T>) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, but switches to a fallback Observable if either the first item emitted by the source Observable or any subsequent item doesn't arrive within time windows defined by other Observables.
timeout(Func1<? super T, ? extends Observable<V>>) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, but notifies observers of a TimeoutException if an item emitted by the source Observable doesn't arrive within a window of time after the emission of the previous item, where that period of time is measured by an Observable that is a function of the previous item.
timeout(Func1<? super T, ? extends Observable<V>>, Observable<? extends T>) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable, but that switches to a fallback Observable if an item emitted by the source Observable doesn't arrive within a window of time after the emission of the previous item, where that period of time is measured by an Observable that is a function of the previous item.
timeout(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item.
timeout(long, TimeUnit, Observable<? extends T>) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item.
timeout(long, TimeUnit, Observable<? extends T>, Scheduler) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item using a specified Scheduler.
timeout(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item, where this policy is governed on a specified Scheduler.
timeout(long, TimeUnit) - Method in class rx.Single
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item.
timeout(long, TimeUnit, Scheduler) - Method in class rx.Single
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item, where this policy is governed on a specified Scheduler.
timeout(long, TimeUnit, Single<? extends T>) - Method in class rx.Single
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item.
timeout(long, TimeUnit, Single<? extends T>, Scheduler) - Method in class rx.Single
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item, using a specified Scheduler.
timeout0(long, TimeUnit, Scheduler, Completable) - Method in class rx.Completable
Returns a Completable that runs this Completable and optionally switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.
timer(long, TimeUnit) - Static method in class rx.Completable
Returns a Completable instance that fires its onComplete event after the given delay elapsed.
timer(long, TimeUnit, Scheduler) - Static method in class rx.Completable
Returns a Completable instance that fires its onCompleted event after the given delay elapsed by using the supplied scheduler.
timer(long, long, TimeUnit) - Static method in class rx.Observable
timer(long, long, TimeUnit, Scheduler) - Static method in class rx.Observable
timer(long, TimeUnit) - Static method in class rx.Observable
Returns an Observable that emits 0L after a specified delay, and then completes.
timer(long, TimeUnit, Scheduler) - Static method in class rx.Observable
Returns an Observable that emits 0L after a specified delay, on a specified Scheduler, and then completes.
timestamp() - Method in class rx.Observable
Returns an Observable that emits each item emitted by the source Observable, wrapped in a Timestamped object.
timestamp(Scheduler) - Method in class rx.Observable
Returns an Observable that emits each item emitted by the source Observable, wrapped in a Timestamped object whose timestamps are provided by a specified Scheduler.
Timestamped<T> - Class in rx.schedulers
Composite class that takes a value and a timestamp and wraps them.
Timestamped(long, T) - Constructor for class rx.schedulers.Timestamped
 
to(Func1<? super Completable, R>) - Method in class rx.Completable
Calls the specified converter function during assembly time and returns its resulting value.
to(Func1<? super Observable<T>, R>) - Method in class rx.Observable
Calls the specified converter function during assembly time and returns its resulting value.
to(Func1<? super Single<T>, R>) - Method in class rx.Single
Calls the specified converter function during assembly time and returns its resulting value.
toAction1(Action0) - Static method in class rx.functions.Actions
Wraps an Action0 instance into an Action1 instance where the latter calls the former.
toBlocking() - Method in class rx.Observable
Converts an Observable into a BlockingObservable (an Observable with blocking operators).
toBlocking() - Method in class rx.Single
Converts a Single into a BlockingSingle (a Single with blocking operators).
toCompletable() - Method in class rx.Observable
Returns a Completable that discards all onNext emissions (similar to ignoreAllElements()) and calls onCompleted when this source observable calls onCompleted.
toCompletable() - Method in class rx.Single
Returns a Completable that discards result of the Single (similar to Observable.ignoreElements()) and calls onCompleted when this source Single calls onSuccess.
toFunc(Action0) - Static method in class rx.functions.Actions
Converts an Action0 to a function that calls the action and returns null.
toFunc(Action1<T1>) - Static method in class rx.functions.Actions
Converts an Action1 to a function that calls the action and returns null.
toFunc(Action2<T1, T2>) - Static method in class rx.functions.Actions
Converts an Action2 to a function that calls the action and returns null.
toFunc(Action3<T1, T2, T3>) - Static method in class rx.functions.Actions
Converts an Action3 to a function that calls the action and returns null.
toFunc(Action4<T1, T2, T3, T4>) - Static method in class rx.functions.Actions
Converts an Action4 to a function that calls the action and returns null.
toFunc(Action5<T1, T2, T3, T4, T5>) - Static method in class rx.functions.Actions
Converts an Action5 to a function that calls the action and returns null.
toFunc(Action6<T1, T2, T3, T4, T5, T6>) - Static method in class rx.functions.Actions
Converts an Action6 to a function that calls the action and returns null.
toFunc(Action7<T1, T2, T3, T4, T5, T6, T7>) - Static method in class rx.functions.Actions
Converts an Action7 to a function that calls the action and returns null.
toFunc(Action8<T1, T2, T3, T4, T5, T6, T7, T8>) - Static method in class rx.functions.Actions
Converts an Action8 to a function that calls the action and returns null.
toFunc(Action9<T1, T2, T3, T4, T5, T6, T7, T8, T9>) - Static method in class rx.functions.Actions
Converts an Action9 to a function that calls the action and returns null.
toFunc(ActionN) - Static method in class rx.functions.Actions
Converts an ActionN to a function that calls the action and returns null.
toFunc(Action0, R) - Static method in class rx.functions.Actions
Converts an Action0 to a function that calls the action and returns a specified value.
toFunc(Action1<T1>, R) - Static method in class rx.functions.Actions
Converts an Action1 to a function that calls the action and returns a specified value.
toFunc(Action2<T1, T2>, R) - Static method in class rx.functions.Actions
Converts an Action2 to a function that calls the action and returns a specified value.
toFunc(Action3<T1, T2, T3>, R) - Static method in class rx.functions.Actions
Converts an Action3 to a function that calls the action and returns a specified value.
toFunc(Action4<T1, T2, T3, T4>, R) - Static method in class rx.functions.Actions
Converts an Action4 to a function that calls the action and returns a specified value.
toFunc(Action5<T1, T2, T3, T4, T5>, R) - Static method in class rx.functions.Actions
Converts an Action5 to a function that calls the action and returns a specified value.
toFunc(Action6<T1, T2, T3, T4, T5, T6>, R) - Static method in class rx.functions.Actions
Converts an Action6 to a function that calls the action and returns a specified value.
toFunc(Action7<T1, T2, T3, T4, T5, T6, T7>, R) - Static method in class rx.functions.Actions
Converts an Action7 to a function that calls the action and returns a specified value.
toFunc(Action8<T1, T2, T3, T4, T5, T6, T7, T8>, R) - Static method in class rx.functions.Actions
Converts an Action8 to a function that calls the action and returns a specified value.
toFunc(Action9<T1, T2, T3, T4, T5, T6, T7, T8, T9>, R) - Static method in class rx.functions.Actions
Converts an Action9 to a function that calls the action and returns a specified value.
toFunc(ActionN, R) - Static method in class rx.functions.Actions
Converts an ActionN to a function that calls the action and returns a specified value.
toFuture() - Method in class rx.observables.BlockingObservable
Returns a Future representing the single value emitted by this BlockingObservable.
toFuture() - Method in class rx.singles.BlockingSingle
Returns a Future representing the value emitted by this BlockingSingle.
toIterable() - Method in class rx.observables.BlockingObservable
Converts this BlockingObservable into an Iterable.
toList() - Method in class rx.Observable
Returns an Observable that emits a single item, a list composed of all the items emitted by the source Observable.
toMap(Func1<? super T, ? extends K>) - Method in class rx.Observable
Returns an Observable that emits a single HashMap containing all items emitted by the source Observable, mapped by the keys returned by a specified keySelector function.
toMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Method in class rx.Observable
Returns an Observable that emits a single HashMap containing values corresponding to items emitted by the source Observable, mapped by the keys returned by a specified keySelector function.
toMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, V>>) - Method in class rx.Observable
Returns an Observable that emits a single Map, returned by a specified mapFactory function, that contains keys and values extracted from the items emitted by the source Observable.
toMultimap(Func1<? super T, ? extends K>) - Method in class rx.Observable
Returns an Observable that emits a single HashMap that contains an ArrayList of items emitted by the source Observable keyed by a specified keySelector function.
toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Method in class rx.Observable
Returns an Observable that emits a single HashMap that contains an ArrayList of values extracted by a specified valueSelector function from items emitted by the source Observable, keyed by a specified keySelector function.
toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>) - Method in class rx.Observable
Returns an Observable that emits a single Map, returned by a specified mapFactory function, that contains an ArrayList of values, extracted by a specified valueSelector function from items emitted by the source Observable and keyed by the keySelector function.
toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>, Func1<? super K, ? extends Collection<V>>) - Method in class rx.Observable
Returns an Observable that emits a single Map, returned by a specified mapFactory function, that contains a custom collection of values, extracted by a specified valueSelector function from items emitted by the source Observable, and keyed by the keySelector function.
toObservable() - Method in class rx.Completable
Returns an Observable which when subscribed to subscribes to this Completable and relays the terminal events to the subscriber.
toObservable() - Method in class rx.Single
Converts this Single into an Observable.
toSerialized() - Method in class rx.subjects.Subject
Wraps a Subject so that it is safe to call its various on methods from different threads.
toSingle(Func0<? extends T>) - Method in class rx.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() - Method in class rx.Observable
Returns a Single that emits the single item emitted by the source Observable, if that Observable emits only a single item.
toSingleDefault(T) - Method in class rx.Completable
Converts this Completable into a Single which when this Completable completes normally, emits the given value through onSuccess.
toSortedList() - Method in class rx.Observable
Returns an Observable that emits a list that contains the items emitted by the source Observable, in a sorted order.
toSortedList(Func2<? super T, ? super T, Integer>) - Method in class rx.Observable
Returns an Observable that emits a list that contains the items emitted by the source Observable, in a sorted order based on a specified comparison function.
toSortedList(int) - Method in class rx.Observable
Returns an Observable that emits a list that contains the items emitted by the source Observable, in a sorted order.
toSortedList(Func2<? super T, ? super T, Integer>, int) - Method in class rx.Observable
Returns an Observable that emits a list that contains the items emitted by the source Observable, in a sorted order based on a specified comparison function.
toString() - Method in class rx.Notification
 
toString() - Method in class rx.schedulers.TimeInterval
 
toString() - Method in class rx.schedulers.Timestamped
 
trampoline() - Static method in class rx.schedulers.Schedulers
Creates and returns a Scheduler that queues work on the current thread to be executed after the current work completes.
TrampolineScheduler - Class in rx.schedulers
Deprecated.
This type was never publicly instantiable. Use Schedulers.trampoline().
triggerActions() - Method in class rx.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.

U

UnicastSubject<T> - Class in rx.subjects
A Subject variant which buffers events until a single Subscriber arrives and replays them to it and potentially switches to direct delivery once the Subscriber caught up and requested an unlimited amount.
unsafeCreate(Observable.OnSubscribe<T>) - Static method in class rx.Observable
Returns an Observable that executes the given OnSubscribe action for each individual Subscriber that subscribes; unsubscription and backpressure must be implemented manually.
unsafeSubscribe(CompletableSubscriber) - Method in class rx.Completable
Subscribes the given CompletableSubscriber to this Completable instance.
unsafeSubscribe(Subscriber<T>) - Method in class rx.Completable
Subscribes a regular Subscriber to this Completable instance which will receive only an onError or onComplete event.
unsafeSubscribe(Subscriber<? super T>) - Method in class rx.Observable
Subscribes to an Observable and invokes Observable.OnSubscribe function without any contract protection, error handling, unsubscribe, or execution hooks.
unsafeSubscribe(Subscriber<? super T>) - Method in class rx.Single
Subscribes to a Single and invokes the Single.OnSubscribe function without any contract protection, error handling, unsubscribe, or execution hooks.
unsubscribe() - Method in interface rx.observers.AssertableSubscriber
 
unsubscribe() - Method in class rx.observers.AsyncCompletableSubscriber
 
unsubscribe() - Method in class rx.observers.SafeCompletableSubscriber
 
unsubscribe() - Method in class rx.SingleSubscriber
 
unsubscribe() - Method in class rx.Subscriber
 
unsubscribe() - Method in interface rx.Subscription
Stops the receipt of notifications on the Subscriber that was registered when this Subscription was received.
unsubscribe() - Method in class rx.subscriptions.BooleanSubscription
 
unsubscribe() - Method in class rx.subscriptions.CompositeSubscription
Unsubscribes itself and all inner subscriptions.
unsubscribe() - Method in class rx.subscriptions.MultipleAssignmentSubscription
 
unsubscribe() - Method in class rx.subscriptions.RefCountSubscription
 
unsubscribe() - Method in class rx.subscriptions.SerialSubscription
 
unsubscribed() - Static method in class rx.subscriptions.Subscriptions
Returns a Subscription to which unsubscribe does nothing, as it is already unsubscribed.
UnsubscribeFailedException - Exception in rx.exceptions
Represents an exception used to re-throw errors thrown from Subscriber.unsubscribe().
UnsubscribeFailedException(Throwable) - Constructor for exception rx.exceptions.UnsubscribeFailedException
Wraps the Throwable before it is to be re-thrown as an OnErrorFailedException.
UnsubscribeFailedException(String, Throwable) - Constructor for exception rx.exceptions.UnsubscribeFailedException
Customizes the Throwable with a custom message and wraps it before it is to be re-thrown as an UnsubscribeFailedException.
unsubscribeOn(Scheduler) - Method in class rx.Completable
Returns a Completable which makes sure when a subscriber cancels the subscription, the dispose is called on the specified scheduler
unsubscribeOn(Scheduler) - Method in class rx.Observable
Modifies the source Observable so that subscribers will unsubscribe from it on a specified Scheduler.
unsubscribeOn(Scheduler) - Method in class rx.Single
Returns a Single which makes sure when a subscriber cancels the subscription, the dispose is called on the specified scheduler
using(Func0<R>, Func1<? super R, ? extends Completable>, Action1<? super R>) - Static method in class rx.Completable
Returns a Completable instance which manages a resource along with a custom Completable instance while the subscription is active.
using(Func0<R>, Func1<? super R, ? extends Completable>, Action1<? super R>, boolean) - Static method in class rx.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(Func0<Resource>, Func1<? super Resource, ? extends Observable<? extends T>>, Action1<? super Resource>) - Static method in class rx.Observable
Constructs an Observable that creates a dependent resource object which is disposed of on unsubscription.
using(Func0<Resource>, Func1<? super Resource, ? extends Observable<? extends T>>, Action1<? super Resource>, boolean) - Static method in class rx.Observable
Constructs an Observable that creates a dependent resource object which is disposed of just before termination if you have set disposeEagerly to true and unsubscription does not occur before termination.
using(Func0<Resource>, Func1<? super Resource, ? extends Single<? extends T>>, Action1<? super Resource>) - Static method in class rx.Single
Constructs a Single that creates a dependent resource object which is disposed of on unsubscription.
using(Func0<Resource>, Func1<? super Resource, ? extends Single<? extends T>>, Action1<? super Resource>, boolean) - Static method in class rx.Single
Constructs a Single that creates a dependent resource object which is disposed of just before termination if you have set disposeEagerly to true and unsubscription does not occur before termination.

V

value() - Method in class rx.singles.BlockingSingle
Returns the item emitted by this BlockingSingle.
valueOf(String) - Static method in enum rx.Emitter.BackpressureMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum rx.Notification.Kind
Returns the enum constant of this type with the specified name.
values() - Static method in enum rx.Emitter.BackpressureMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum rx.Notification.Kind
Returns an array containing the constants of this enum type, in the order they are declared.

W

when(Func1<Observable<Observable<Completable>>, Completable>) - Method in class rx.Scheduler
Allows the use of operators for controlling the timing around when actions scheduled on workers are actually done.
window(Func0<? extends Observable<? extends TClosing>>) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(int) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(int, int) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, long, TimeUnit, int, Scheduler) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, TimeUnit, int) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, TimeUnit, int, Scheduler) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(Observable<U>) - Method in class rx.Observable
Returns an Observable that emits non-overlapping windows of items it collects from the source Observable where the boundary of each window is determined by the items emitted from a specified boundary-governing Observable.
withLatestFrom(Observable<? extends U>, Func2<? super T, ? super U, ? extends R>) - Method in class rx.Observable
Merges the specified Observable into this Observable sequence by using the resultSelector function only when the source Observable (this instance) emits an item.
withLatestFrom(Observable<T1>, Observable<T2>, Func3<? super T, ? super T1, ? super T2, R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
withLatestFrom(Observable<T1>, Observable<T2>, Observable<T3>, Func4<? super T, ? super T1, ? super T2, ? super T3, R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
withLatestFrom(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Func5<? super T, ? super T1, ? super T2, ? super T3, ? super T4, R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
withLatestFrom(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>, Func6<? super T, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
withLatestFrom(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>, Observable<T6>, Func7<? super T, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
withLatestFrom(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>, Observable<T6>, Observable<T7>, Func8<? super T, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
withLatestFrom(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>, Observable<T6>, Observable<T7>, Observable<T8>, Func9<? super T, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
withLatestFrom(Observable<?>[], FuncN<R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
withLatestFrom(Iterable<Observable<?>>, FuncN<R>) - Method in class rx.Observable
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
Worker() - Constructor for class rx.Scheduler.Worker
 
wrap(Subscriber<? super T>) - Static method in class rx.observers.Subscribers
Returns a new Subscriber that passes all events to subscriber, has backpressure controlled by subscriber and uses the subscription list of subscriber when Subscriber.add(rx.Subscription) is called.

Z

zip(Iterable<? extends Observable<?>>, FuncN<? extends R>) - Static method in class rx.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 Observables.
zip(Observable<?>[], FuncN<? extends R>) - Static method in class rx.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 Observables.
zip(Observable<? extends Observable<?>>, FuncN<? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a specified combiner function applied to combinations of n items emitted, in sequence, by the n Observables emitted by a specified Observable.
zip(Observable<? extends T1>, Observable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.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 Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.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 Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Func4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.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 Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Func5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.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 Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Func6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.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 Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Func7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.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 Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Func8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.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 Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Observable<? extends T9>, Func9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class rx.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 Observables.
zip(Single<? extends T1>, Single<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.Single
Returns a Single that emits the results of a specified combiner function applied to two items emitted by two other Singles.
zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.Single
Returns a Single that emits the results of a specified combiner function applied to three items emitted by three other Singles.
zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Func4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.Single
Returns an Observable that emits the results of a specified combiner function applied to four items emitted by four other Singles.
zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Func5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.Single
Returns an Observable that emits the results of a specified combiner function applied to five items emitted by five other Singles.
zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Single<? extends T6>, Func6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.Single
Returns an Observable that emits the results of a specified combiner function applied to six items emitted by six other Singles.
zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Single<? extends T6>, Single<? extends T7>, Func7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.Single
Returns an Observable that emits the results of a specified combiner function applied to seven items emitted by seven other Singles.
zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Single<? extends T6>, Single<? extends T7>, Single<? extends T8>, Func8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.Single
Returns an Observable that emits the results of a specified combiner function applied to eight items emitted by eight other Singles.
zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Single<? extends T6>, Single<? extends T7>, Single<? extends T8>, Single<? extends T9>, Func9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class rx.Single
Returns an Observable that emits the results of a specified combiner function applied to nine items emitted by nine other Singles.
zip(Iterable<? extends Single<?>>, FuncN<? extends R>) - Static method in class rx.Single
Returns a Single that emits the result of specified combiner function applied to combination of items emitted, in sequence, by an Iterable of other Singles.
zipWith(Iterable<? extends T2>, Func2<? super T, ? super T2, ? extends R>) - Method in class rx.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 Observable and a specified Iterable sequence.
zipWith(Observable<? extends T2>, Func2<? super T, ? super T2, ? extends R>) - Method in class rx.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 Observable and another specified Observable.
zipWith(Single<? extends T2>, Func2<? super T, ? super T2, ? extends R>) - Method in class rx.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.

_

_onError(Throwable) - Method in class rx.observers.SafeSubscriber
The logic for onError without the isFinished check so it can be called from within onCompleted.
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