- 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.
- 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.
- asObservable() - Method in class rx.Observable
-
Portrays a object of an Observable subclass as a simple Observable object.
- assertCompleted() - Method in class rx.observers.TestSubscriber
-
Asserts that there is exactly one completion event.
- 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.
- assertNoErrors() - Method in class rx.observers.TestSubscriber
-
Asserts that this Subscriber
has received no onError
notifications.
- assertNotCompleted() - Method in class rx.observers.TestSubscriber
-
Asserts that there is no completion event.
- assertNoTerminalEvent() - Method in class rx.observers.TestSubscriber
-
Asserts that there are no onError and onCompleted events.
- assertNoValues() - Method in class rx.observers.TestSubscriber
-
Asserts that there are no onNext events received.
- assertReceivedOnNext(List<T>) - Method in class rx.observers.TestObserver
-
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.
- assertTerminalEvent() - Method in class rx.observers.TestObserver
-
- assertTerminalEvent() - Method in class rx.observers.TestSubscriber
-
- assertUnsubscribed() - Method in class rx.observers.TestSubscriber
-
Asserts that this Subscriber
is unsubscribed.
- 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 class rx.observers.TestSubscriber
-
Asserts that the given number of onNext events are received.
- assertValues(T...) - Method in class rx.observers.TestSubscriber
-
Asserts that the received onNext events, in order, are the specified items.
- 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
that has subscribed, when the
source
Observable
completes.
- AsyncSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>) - Constructor for class rx.subjects.AsyncSubject
-
- 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 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 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).
- cache() - Method in class rx.Observable
-
Caches the emissions from the source Observable and replays them in order to any subsequent Subscribers.
- cache(int) - Method in class rx.Observable
-
- cacheWithInitialCapacity(int) - Method in class rx.Observable
-
Caches emissions from the source Observable and replays them in order to any subsequent 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
-
- 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.
- 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.
- 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.CompletableOnSubscribe) - Constructor for class rx.Completable
-
Constructs a Completable instance with the given onSubscribe callback.
- Completable.CompletableOnSubscribe - Interface in rx
-
Callback used for building deferred computations that takes a CompletableSubscriber.
- Completable.CompletableOperator - 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.CompletableSubscriber - Interface in rx
-
Represents the subscription API callbacks when subscribing to a Completable instance.
- Completable.CompletableTransformer - Interface in rx
-
Convenience interface and callback used by the compose operator to turn a Completable into another
Completable fluently.
- complete() - Static method in class rx.Completable
-
Returns a Completable instance that completes immediately when subscribed to.
- compose(Completable.CompletableTransformer) - 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
-
- 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
-
- 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(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.
- 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
Subscriber
s.
- connect(Action1<? super Subscription>) - Method in class rx.observables.ConnectableObservable
-
Instructs the
ConnectableObservable
to begin emitting the items from its underlying
Observable
to its
Subscriber
s.
- ConnectableObservable<T> - Class in rx.observables
-
- 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.CompletableOnSubscribe) - 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
-
Returns an Observable that will execute the specified function when a
Subscriber
subscribes to
it.
- 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
-
- 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
-
- create(Action1<? super T>) - Static method in class rx.observers.Subscribers
-
- 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
-
- 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
-
- create() - Static method in class rx.subjects.AsyncSubject
-
Creates and returns a new AsyncSubject
.
- create() - Static method in class rx.subjects.BehaviorSubject
-
- 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.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
-
- createComputationScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
-
- createComputationScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
-
- createIoScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
-
- createIoScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
-
- createNewThreadScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
-
- createNewThreadScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
-
- 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
-
Creates and returns a Notification
of variety Kind.OnCompleted
.
- 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.
- 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 an 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 an 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.
- 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
-
- doAfterTerminate(Action0) - Method in class rx.Single
-
- doOnComplete(Action0) - Method in class rx.Completable
-
- 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<? super T>>) - Method in class rx.Observable
-
Modifies the source Observable so that it invokes an action for each item it emits.
- doOnEach(Observer<? super T>) - Method in class rx.Observable
-
Modifies the source Observable so that it notifies an Observer for each item it emits.
- 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<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<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.
- 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
-
- 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.
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- generateState() - Method in class rx.observables.AsyncOnSubscribe
-
Executed once when subscribed to by a subscriber (via OnSubscribe#call(Subscriber)
)
to produce a state value.
- generateState() - Method in class rx.observables.SyncOnSubscribe
-
Executed once when subscribed to by a subscriber (via OnSubscribe#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
-
Retrieves the current
Subscription
that is being represented by this
SerialSubscription
.
- getActual() - Method in class rx.observers.SafeSubscriber
-
Returns the
Subscriber
underlying this
SafeSubscriber
.
- getCause() - Method in exception rx.exceptions.CompositeException
-
- getComputationScheduler() - Method in class rx.plugins.RxJavaSchedulersHook
-
- getDefaultInstance() - Static method in class rx.plugins.RxJavaSchedulersHook
-
- getErrorHandler() - Method in class rx.plugins.RxJavaPlugins
-
- getEvents() - Method in class rx.observers.TestObserver
-
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 Throwable
s, 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
-
Retrieves the single RxJavaPlugins
instance.
- 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 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
-
- getObservableExecutionHook() - Method in class rx.plugins.RxJavaPlugins
-
- getOnCompletedEvents() - Method in class rx.observers.TestObserver
-
- getOnCompletedEvents() - Method in class rx.observers.TestSubscriber
-
- getOnErrorEvents() - Method in class rx.observers.TestObserver
-
- getOnErrorEvents() - Method in class rx.observers.TestSubscriber
-
- getOnNextEvents() - Method in class rx.observers.TestObserver
-
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
.
- getSchedulersHook() - Method in class rx.plugins.RxJavaPlugins
-
- getSingleExecutionHook() - Method in class rx.plugins.RxJavaPlugins
-
- 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
-
- 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
GroupedObservable
s.
- 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
GroupedObservable
s.
- GroupedObservable<K,T> - Class in rx.observables
-
- 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.
- 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.
- 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.
- 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
-
- 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
-
- 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 other than the
RxRingBuffer.SIZE
default.
- 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 other than the
RxRingBuffer.SIZE
default, 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
-
- ON_OVERFLOW_DROP_LATEST - Static variable in class rx.BackpressureOverflow
-
- ON_OVERFLOW_DROP_OLDEST - Static variable in class rx.BackpressureOverflow
-
- ON_OVERFLOW_ERROR - Static variable in class rx.BackpressureOverflow
-
- 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.
- onCompleted() - Method in interface rx.Completable.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.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
-
- 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.
- OnCompletedFailedException - Exception in rx.exceptions
-
- 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
.
- onCreate(Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- onCreate(Single.OnSubscribe<T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
- onError(Throwable) - Method in interface rx.Completable.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.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
-
- onError(Throwable) - Method in class rx.observers.TestSubscriber
-
Notifies the Subscriber that the Observable
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.
- 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
-
- 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
-
- 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<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
-
- onErrorResumeNext(Func1<Throwable, ? extends Single<? extends T>>) - Method in class rx.Single
-
- onErrorReturn(Func1<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.
- OnErrorThrowable.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.
- 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
.
- onLift(Observable.Operator<? extends R, ? super T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
Invoked just as the operator functions is called to bind two operations together into a new
Observable
and the return value is used as the lifted function
- onLift(Observable.Operator<? extends R, ? super T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
Invoked just as the operator functions is called to bind two operations together into a new
Single
and the return value is used as the lifted function
- 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
-
- 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.
- onSchedule(Action0) - Method in class rx.plugins.RxJavaSchedulersHook
-
Invoked before the Action is handed over to the scheduler.
- 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.Completable.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.
- onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
- onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
- onSubscribeStart(Observable<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- onSubscribeStart(Single<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
- 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.
- 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.
- 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
.
- 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
-
- 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
-
- remove(Subscription) - Method in class rx.subscriptions.CompositeSubscription
-
- 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
-
- 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.
- requestMore(long) - Method in class rx.observers.TestSubscriber
-
- reset() - Method in class rx.plugins.RxJavaPlugins
-
Reset RxJavaPlugins
instance
- 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 an 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 an 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
-
Rx Observables
- rx.annotations - package rx.annotations
-
- rx.exceptions - package rx.exceptions
-
- rx.functions - package rx.functions
-
- rx.observables - package rx.observables
-
- rx.observers - package rx.observers
-
- rx.plugins - package rx.plugins
-
- rx.schedulers - package rx.schedulers
-
Rx Schedulers
- rx.singles - package rx.singles
-
- rx.subjects - package rx.subjects
-
- rx.subscriptions - package rx.subscriptions
-
- RxJavaErrorHandler - Class in rx.plugins
-
- RxJavaErrorHandler() - Constructor for class rx.plugins.RxJavaErrorHandler
-
- 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
-
- 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.
- Scheduler.Worker() - Constructor for class rx.Scheduler.Worker
-
- 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
-
Swaps out the old
Subscription
for the specified
Subscription
.
- setProducer(Producer) - Method in class rx.Subscriber
-
- share() - Method in class rx.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.OnSubscribe<T> - Interface in rx
-
Invoked when Single.execute is called.
- Single.Transformer<T,R> - Interface in rx
-
- 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.
- 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(Action1<? super Throwable>, Action0) - Method in class rx.Completable
-
Subscribes to this Completable and calls back either the onError or onComplete functions.
- subscribe(Completable.CompletableSubscriber) - Method in class rx.Completable
-
Subscribes the given CompletableSubscriber to this Completable instance.
- subscribe(Subscriber<T>) - Method in class rx.Completable
-
Subscribes a reactive-streams Subscriber to this Completable instance which
will receive only an onError or onComplete event.
- 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) - 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
-
- 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 respond correctly to back
pressure requests from subscribers.
- SyncOnSubscribe() - Constructor for class rx.observables.SyncOnSubscribe
-
- 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 if 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() - Static method in class rx.schedulers.Schedulers
-
Creates and returns a TestScheduler
, which is useful for debugging.
- TestObserver<T> - Class in rx.observers
-
Observer usable for unit testing to perform assertions, inspect received events or wrap a mocked Observer.
- TestObserver(Observer<T>) - Constructor for class rx.observers.TestObserver
-
- TestObserver() - Constructor for class rx.observers.TestObserver
-
- 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, 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 onComplete 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 one item after a specified delay, and then completes.
- timer(long, TimeUnit, Scheduler) - Static method in class rx.Observable
-
Returns an Observable that emits one item 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, U>) - Method in class rx.Completable
-
Allows fluent conversion to another type via a function callback.
- 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
-
- 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
-
- 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
-
- 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
-
- 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.