- 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<T1> - 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.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(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Mirrors the one Observable in an Iterable of several Observables that first emits an item.
- amb(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given two Observables, mirrors the one that first emits an item.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given three Observables, mirrors the one that first emits an item.
- 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 emits an item.
- 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 emits an item.
- 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 emits an item.
- 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 emits an item.
- 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 emits an item.
- 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 emits an item.
- ambWith(Observable<? extends T>) - Method in class rx.Observable
-
Mirrors the first Observable (current or provided) that emits an item.
- asObservable() - Method in class rx.Observable
-
Portrays a object of an Observable subclass as a simple Observable object.
- assertNoErrors() - Method in class rx.observers.TestSubscriber
-
Assert that this Subscriber
has received no onError
notifications.
- 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
-
Assert 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
-
Assert that this Subscriber
is unsubscribed.
- 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
-
- 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
-
Caches emissions from the source Observable and replays them in order to any subsequent Subscribers.
- call() - Method in interface rx.functions.Action0
-
- call(T1) - 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(T1) - 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
-
- 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 in
an unoperative state.
- 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.
- compose(Observable.Transformer<? super T, ? extends R>) - Method in class rx.Observable
-
Transform an Observable 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
-
- 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(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.
- 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 concatinating those resulting Observables.
- 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.
- 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(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(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.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
-
- 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.
- 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
-
- createWorker() - Method in class rx.schedulers.NewThreadScheduler
-
- createWorker() - Method in class rx.schedulers.TestScheduler
-
- createWorker() - Method in class rx.schedulers.TrampolineScheduler
-
- 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<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.
- 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 souce 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.
- 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.
- 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.
- 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<Throwable>) - Method in class rx.Observable
-
Modifies the source Observable so that it invokes an action if it calls onError
.
- doOnNext(Action1<? super T>) - Method in class rx.Observable
-
Modifies the source Observable so that it invokes an action when it calls onNext
.
- 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.
- 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.Observable
-
Modifies the source Observable
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>>, 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 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.
- 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 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.
- 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<?>) - 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.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.
- 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.
- Func0<R> - Interface in rx.functions
-
Represents a function with zero arguments.
- Func1<T1,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
-
- 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 emited 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
-
Get the sequence of items observed by this
Subscriber
, as an ordered
List
.
- getSchedulersHook() - Method in class rx.plugins.RxJavaPlugins
-
- getThrowable() - Method in class rx.Notification
-
Retrieves the exception associated with this (onError) notification.
- 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.
- 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, one
GroupedObservable
per group.
- 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, one
GroupedObservable
per group.
- 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.
- 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.
- 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.
- 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 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(Observable<? extends T>) - Method in class rx.Observable
-
Flattens this and another Observable 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
-
- MissingBackpressureException(String) - Constructor for exception rx.exceptions.MissingBackpressureException
-
- 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 Obserable.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.Observable
-
Modifies an Observable to perform its emissions and notifications on a specified
Scheduler
,
asynchronously with an unbounded buffer.
- 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.
- onBackpressureBlock(int) - Method in class rx.Observable
-
Instructs an Observable that is emitting items faster than its observer can consume them to
block the producer thread.
- onBackpressureBlock() - Method in class rx.Observable
-
Instructs an Observable that is emitting items faster than its observer can consume them to block the
producer thread if the number of undelivered onNext events reaches the system-wide ring buffer size.
- 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.
- 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.
- 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
at relative time of "now()" on TestScheduler.
- onCompleted(long) - Method in class rx.subjects.TestSubject
-
Schedule a call to onCompleted
relative to "now()" +n milliseconds in the future.
- onCreate(Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- 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.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
at relative time of "now()" on TestScheduler.
- onError(Throwable, long) - Method in class rx.subjects.TestSubject
-
Schedule a call to onError
relative to "now()" +n milliseconds in the future.
- 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<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.
- 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.
- 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
- 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
at relative time of "now()" 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.
- onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- onSubscribeStart(Observable<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- 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.
- remove(Subscription) - Method in class rx.subscriptions.CompositeSubscription
-
- 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<?>>, 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
-
- 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.
- 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
.
- 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.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
-
- SafeSubscriber<T> - Class in rx.observers
-
SafeSubscriber
is a wrapper around Subscriber
that ensures that the Subscriber
complies with the Rx 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 Rx 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
-
- 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
-
- 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
.
- 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.
- skip(int) - Method in class rx.Observable
-
Returns an Observable that skips the first num
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(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.Observable
-
Subscribes to an Observable but ignore its emissions and notifications.
- 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.
- subscribeOn(Scheduler) - Method in class rx.Observable
-
Asynchronously subscribes Observers to this Observable 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
-
- 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
- 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.
- 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.
- take(int) - Method in class rx.Observable
-
Returns an Observable that emits only the first num
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 only 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 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.
- 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(Subscriber<T>) - Constructor for class rx.observers.TestSubscriber
-
- TestSubscriber(Observer<T>) - Constructor for class rx.observers.TestSubscriber
-
- TestSubscriber() - Constructor for class rx.observers.TestSubscriber
-
- 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.
- throwIfFatal(Throwable) - Static method in class rx.exceptions.Exceptions
-
Throws a particular Throwable
only if it belongs to a set of "fatal" error varieties.
- 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(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.
- timer(long, long, TimeUnit) - Static method in class rx.Observable
-
Returns an Observable that emits a 0L
after the initialDelay
and ever increasing numbers
after each period
of time thereafter.
- timer(long, long, TimeUnit, Scheduler) - Static method in class rx.Observable
-
Returns an Observable that emits a
0L
after the
initialDelay
and ever increasing numbers
after each
period
of time thereafter, on a specified
Scheduler
.
- 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
-
- toBlocking() - Method in class rx.Observable
-
- 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
.
- 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.
- toSerialized() - Method in class rx.subjects.Subject
-
Wraps a
Subject
so that it is safe to call its various
on
methods from different threads.
- 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.
- 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
-
Schedules work on the current thread but does not execute immediately.
- 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.