- accept(Observer<? super T>, Object) - Method in class rx.internal.operators.NotificationLite
-
Unwraps the lite notification and calls the appropriate method on the
Observer
.
- accept(Object, Observer) - Method in class rx.internal.util.RxRingBuffer
-
- 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
-
- Action1<T1> - Interface in rx.functions
-
- Action2<T1,T2> - Interface in rx.functions
-
- Action3<T1,T2,T3> - Interface in rx.functions
-
- 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.internal.schedulers.ScheduledAction
-
- add(E) - Method in class rx.internal.util.IndexedRingBuffer
-
Add an element and return the index where it was added to allow removal.
- add(T) - Method in class rx.internal.util.SubscriptionIndexedRingBuffer
-
Adds a new
Subscription
to this
CompositeSubscription
if the
CompositeSubscription
is not yet unsubscribed.
- add(Subscription) - Method in class rx.internal.util.SubscriptionList
-
Adds a new
Subscription
to this
SubscriptionList
if the
SubscriptionList
is
not yet unsubscribed.
- add(T) - Method in class rx.internal.util.SubscriptionRandomList
-
Adds a new
Subscription
to this
CompositeSubscription
if the
CompositeSubscription
is not yet unsubscribed.
- add(T) - Method in class rx.internal.util.SynchronizedQueue
-
- add(Subscription) - Method in class rx.Subscriber
-
Adds a
Subscription
to this Subscriber's list of subscriptions if this list is not marked as
unsubscribed.
- add(Subscription) - Method in class rx.subscriptions.CompositeSubscription
-
Adds a new
Subscription
to this
CompositeSubscription
if the
CompositeSubscription
is not yet unsubscribed.
- addAll(Collection<? extends T>) - Method in class rx.internal.util.SynchronizedQueue
-
- 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).
- addParent(CompositeSubscription) - Method in class rx.internal.schedulers.ScheduledAction
-
Adds a parent
CompositeSubscription
to this
ScheduledAction
so when the action is
cancelled or terminates, it can remove itself from this parent.
- 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.
- alwaysFalse() - Static method in class rx.functions.Functions
-
Returns a function that always returns false
.
- alwaysTrue() - Static method in class rx.functions.Functions
-
Returns a function that always returns true
.
- amb(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given two
Observable
s, propagates the one that first emits an item.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given three
Observable
s, propagates 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.internal.operators.OnSubscribeAmb
-
Given four
Observable
s, propagates 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.internal.operators.OnSubscribeAmb
-
Given five
Observable
s, propagates 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.internal.operators.OnSubscribeAmb
-
Given six
Observable
s, propagates 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.internal.operators.OnSubscribeAmb
-
Given seven
Observable
s, propagates 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.internal.operators.OnSubscribeAmb
-
Given eight
Observable
s, propagates 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.internal.operators.OnSubscribeAmb
-
Given nine
Observable
s, propagates the one that first emits an item.
- amb(Iterable<? extends Observable<? extends T>>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given a set of
Observable
s, propagates the one that first emits an item.
- 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.
- asError(Object) - Method in class rx.internal.util.RxRingBuffer
-
- asObservable() - Method in class rx.Observable
-
Disguises 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
-
- available() - Method in class rx.internal.util.RxRingBuffer
-
- 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 - Variable in class rx.internal.operators.OnSubscribeCache
-
- 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.
- calcElementOffset(long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
- calcSequenceOffset(long) - Method in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
-
- 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
-
- call(T) - Method in class rx.functions.Not
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeAmb
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeCache
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeCombineLatest
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDefer
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDelay
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDelay.Emitter
-
- call() - Method in class rx.internal.operators.OnSubscribeDelay.Emitter
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDelaySubscription
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDelayWithSelector
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeFromIterable
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeGroupJoin
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeJoin
-
- call(Subscriber<? super TResult>) - Method in class rx.internal.operators.OnSubscribeMulticastSelector
-
- call(Subscriber<? super Integer>) - Method in class rx.internal.operators.OnSubscribeRange
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeRedo
-
- call(Observable<? extends Notification<?>>) - Method in class rx.internal.operators.OnSubscribeRedo.RedoFinite
-
- call(Observable<? extends Notification<?>>) - Method in class rx.internal.operators.OnSubscribeRedo.RetryWithPredicate
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeRefCount
-
- call(Subscriber<? super Long>) - Method in class rx.internal.operators.OnSubscribeTimerOnce
-
- call(Subscriber<? super Long>) - Method in class rx.internal.operators.OnSubscribeTimerPeriodically
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeUsing
-
- call(Subscriber<? super Boolean>) - Method in class rx.internal.operators.OperatorAll
-
- call(Subscriber<? super Boolean>) - Method in class rx.internal.operators.OperatorAny
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorAsObservable
-
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorBufferWithSingleObservable
-
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorBufferWithSize
-
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorBufferWithStartEndObservable
-
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorBufferWithTime
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorCast
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorConcat
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDebounceWithSelector
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDebounceWithTime
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDefaultIfEmpty
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDematerialize
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDistinct
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDistinctUntilChanged
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDoOnEach
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDoOnSubscribe
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDoOnUnsubscribe
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorElementAt
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorFilter
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorFinally
-
- call(Subscriber<? super GroupedObservable<K, R>>) - Method in class rx.internal.operators.OperatorGroupBy
-
- call(Subscriber<? super GroupedObservable<K, R>>) - Method in class rx.internal.operators.OperatorGroupByUntil
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorMap
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorMapNotification
-
- call(Subscriber<? super Observable<? extends R>>) - Method in class rx.internal.operators.OperatorMapPair
-
- call(Subscriber<? super Notification<T>>) - Method in class rx.internal.operators.OperatorMaterialize
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorMerge
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorMergeMaxConcurrent
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorObserveOn
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnBackpressureBuffer
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnBackpressureDrop
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnErrorFlatMap
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnErrorResumeNextViaFunction
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnErrorResumeNextViaObservable
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnErrorReturn
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnExceptionResumeNextViaObservable
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorRetryWithPredicate
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSampleWithObservable
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSampleWithTime
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorScan
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSerialize
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSingle
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkip
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipLast
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipLastTimed
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipTimed
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipUntil
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipWhile
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSubscribeOn
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSwitch
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTake
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeLast
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeLastTimed
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeTimed
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeUntil
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeWhile
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorThrottleFirst
-
- call(Subscriber<? super TimeInterval<T>>) - Method in class rx.internal.operators.OperatorTimeInterval
-
- call(Subscriber<? super Timestamped<T>>) - Method in class rx.internal.operators.OperatorTimestamp
-
- call(Subscriber<? super Map<K, V>>) - Method in class rx.internal.operators.OperatorToMap
-
- call() - Method in class rx.internal.operators.OperatorToMap.DefaultToMapFactory
-
- call(Subscriber<? super Map<K, Collection<V>>>) - Method in class rx.internal.operators.OperatorToMultimap
-
- call(K) - Method in class rx.internal.operators.OperatorToMultimap.DefaultMultimapCollectionFactory
-
- call() - Method in class rx.internal.operators.OperatorToMultimap.DefaultToMultimapFactory
-
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorToObservableList
-
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorToObservableSortedList
-
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorUnsubscribeOn
-
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithObservable
-
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithSize
-
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable
-
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithTime
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorZip
-
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorZipIterable
-
- capacity() - Method in class rx.internal.util.RxRingBuffer
-
- capacity - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
- 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.internal.util.MpscPaddedQueue
-
Clears the queue.
- clear() - Method in class rx.internal.util.SubscriptionRandomList
-
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.
- clear() - Method in class rx.internal.util.SynchronizedQueue
-
- 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.
- clone() - Method in class rx.internal.util.SynchronizedQueue
-
- collect(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.
- compareAndSwapInt(Object, long, int, int) - Static method in class rx.internal.util.unsafe.UnsafeAccess
-
- completed() - Method in class rx.internal.operators.NotificationLite
-
Creates a lite onCompleted
notification without doing any allocation.
- 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
-
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.
- ConcurrentCircularArrayQueue<E> - Class in rx.internal.util.unsafe
-
A concurrent access enabling class used by circular array based queues this class exposes an offset computation
method along with differently memory fenced load/store methods into the underlying array.
- ConcurrentCircularArrayQueue(int) - Constructor for class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
- ConcurrentSequencedCircularArrayQueue<E> - Class in rx.internal.util.unsafe
-
- ConcurrentSequencedCircularArrayQueue(int) - Constructor for class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
-
- connect(Action1<? super Subscription>) - Method in class rx.internal.operators.OperatorMulticast
-
- 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.internal.util.SynchronizedQueue
-
- contains(Object) - Method in class rx.Observable
-
Returns an Observable that emits a Boolean that indicates whether the source Observable emitted a
specified item.
- containsAll(Collection<?>) - Method in class rx.internal.util.SynchronizedQueue
-
- convertSelector(Func1<? super T, ? extends Iterable<? extends U>>) - Static method in class rx.internal.operators.OperatorMapPair
-
Creates the function that generates a Observable
based on an item emitted by another Observable
.
- count() - Method in class rx.internal.util.RxRingBuffer
-
- count() - Method in class rx.Observable
-
Returns an Observable that emits the count of the total number of items emitted by the source Observable.
- create() - Static method in class rx.internal.operators.BufferUntilSubscriber
-
- create(T) - Static method in class rx.internal.util.ScalarSynchronousObservable
-
- 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(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
-
- createObject() - Method in class rx.internal.util.ObjectPool
-
Creates a new object.
- 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.
- createScheduledSubject(Subject<T, T>, Scheduler) - Static method in class rx.internal.operators.OperatorReplay
-
Creates a subject whose client observers will observe events
propagated through the given wrapped subject.
- 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.
- 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(Func1<? super E, Boolean>) - Method in class rx.internal.util.IndexedRingBuffer
-
- forEach(Func1<? super E, Boolean>, int) - Method in class rx.internal.util.IndexedRingBuffer
-
- forEach(Func1<T, Boolean>) - Method in class rx.internal.util.SubscriptionIndexedRingBuffer
-
- forEach(Func1<T, Boolean>, int) - Method in class rx.internal.util.SubscriptionIndexedRingBuffer
-
- forEach(Action1<T>) - Method in class rx.internal.util.SubscriptionRandomList
-
- 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(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
-
- Func1<T1,R> - Interface in rx.functions
-
- Func2<T1,T2,R> - Interface in rx.functions
-
- Func3<T1,T2,T3,R> - Interface in rx.functions
-
- Func4<T1,T2,T3,T4,R> - Interface in rx.functions
-
- Func5<T1,T2,T3,T4,T5,R> - Interface in rx.functions
-
- Func6<T1,T2,T3,T4,T5,T6,R> - Interface in rx.functions
-
- Func7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in rx.functions
-
- Func8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in rx.functions
-
- Func9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in rx.functions
-
- FuncN<R> - Interface in rx.functions
-
- Function - Interface in rx.functions
-
All Func and Action interfaces extend from this.
- Functions - Class in rx.functions
-
- Functions() - Constructor for class rx.functions.Functions
-
- get() - Method in class rx.internal.util.ScalarSynchronousObservable
-
- 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
.
- getAndAddInt(Object, long, int) - Static method in class rx.internal.util.unsafe.UnsafeAccess
-
- getAndIncrementInt(Object, long) - Static method in class rx.internal.util.unsafe.UnsafeAccess
-
- getAndSetInt(Object, long, int) - Static method in class rx.internal.util.unsafe.UnsafeAccess
-
- getCause() - Method in exception rx.exceptions.CompositeException
-
- getComputationScheduler() - Method in class rx.plugins.RxJavaSchedulersHook
-
- getDefaultInstance() - Static method in class rx.plugins.RxJavaSchedulersHook
-
- getError(Object) - Method in class rx.internal.operators.NotificationLite
-
Returns the Throwable
corresponding to this OnError
lite notification.
- 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.internal.util.IndexedRingBuffer
-
- getInstance() - Static method in class rx.plugins.RxJavaErrorHandlerDefault
-
- 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
-
- getSpmcInstance() - Static method in class rx.internal.util.RxRingBuffer
-
- getSpscInstance() - Static method in class rx.internal.util.RxRingBuffer
-
- 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(Object) - Method in class rx.internal.operators.NotificationLite
-
Returns the item corresponding to this OnNext
lite notification.
- getValue(Object) - Method in class rx.internal.util.RxRingBuffer
-
- 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.
- groupByUntil(Func1<? super T, ? extends TKey>, Func1<? super GroupedObservable<TKey, T>, ? extends Observable<? extends TDuration>>) - Method in class rx.Observable
-
Groups the items emitted by an Observable
according to a specified key selector function until
the duration Observable
expires for the key.
- groupByUntil(Func1<? super T, ? extends TKey>, Func1<? super T, ? extends TValue>, Func1<? super GroupedObservable<TKey, TValue>, ? extends Observable<? extends TDuration>>) - Method in class rx.Observable
-
Groups the items emitted by an Observable
(transformed by a selector) according to a specified
key selector function until the duration Observable expires for the key.
- 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.
- last() - Method in class rx.Observable
-
Returns an Observable that emits the last item emitted by the source Observable or notifies observers of
a NoSuchElementException
if the source Observable is empty.
- last(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits only the last item emitted by the source Observable that satisfies a
given condition, or notifies of a NoSuchElementException
if no such items are emitted.
- last() - Method in class rx.observables.BlockingObservable
-
Returns the last item emitted by this BlockingObservable
, or throws
NoSuchElementException
if this BlockingObservable
emits no items.
- last(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
-
Returns the last item emitted by this BlockingObservable
that matches a predicate, or throws
NoSuchElementException
if it emits no such items.
- lastOrDefault(T) - Method in class rx.Observable
-
Returns an Observable that emits only the last item emitted by the source Observable, or a default item
if the source Observable completes without emitting any items.
- lastOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits only the last item emitted by the source Observable that satisfies a
specified condition, or a default item if no such item is emitted by the source Observable.
- lastOrDefault(T) - Method in class rx.observables.BlockingObservable
-
Returns the last item emitted by this BlockingObservable
, or a default value if it emits no
items.
- lastOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
-
Returns the last item emitted by this BlockingObservable
that matches a predicate, or a default
value if it emits no such items.
- latest(Observable<? extends T>) - Static method in class rx.internal.operators.BlockingOperatorLatest
-
Returns an Iterable
that blocks until or unless the Observable
emits an item that has not
been returned by the Iterable
, then returns that item
- latest() - Method in class rx.observables.BlockingObservable
-
Returns an Iterable
that returns the latest item emitted by this BlockingObservable
,
waiting if necessary for one to become available.
- left - Variable in class rx.internal.operators.OnSubscribeGroupJoin
-
- leftDuration - Variable in class rx.internal.operators.OnSubscribeGroupJoin
-
- lift(Observable.Operator<? extends R, ? super T>) - Method in class rx.Observable
-
Lifts a function to the current Observable and returns a new Observable that when subscribed to will pass
the values of the current Observable through the Operator function.
- limit(int) - Method in class rx.Observable
-
Returns an Observable that emits only the first num
items emitted by the source Observable.
- longCount() - 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.
- lpElement(long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A plain load (no ordering/fences) of an element from a given offset.
- lpElement(E[], long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A plain load (no ordering/fences) of an element from a given offset.
- lvElement(long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A volatile load (load + LoadLoad barrier) of an element from a given offset.
- lvElement(E[], long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A volatile load (load + LoadLoad barrier) of an element from a given offset.
- lvSequence(long[], long) - Method in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
-
- 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.
- mask - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
- 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
-
- MissingBackpressureException() - Constructor for exception rx.exceptions.MissingBackpressureException
-
- MissingBackpressureException(String) - Constructor for exception rx.exceptions.MissingBackpressureException
-
- mostRecent(Observable<? extends T>, T) - Static method in class rx.internal.operators.BlockingOperatorMostRecent
-
Returns an Iterable
that always returns the item most recently emitted by the Observable
.
- mostRecent(T) - Method in class rx.observables.BlockingObservable
-
Returns an Iterable
that always returns the item most recently emitted by this
BlockingObservable
.
- MpmcArrayQueue<E> - Class in rx.internal.util.unsafe
-
- MpmcArrayQueue(int) - Constructor for class rx.internal.util.unsafe.MpmcArrayQueue
-
- MpscPaddedQueue<E> - Class in rx.internal.util
-
A multiple-producer single consumer queue implementation with padded reference to tail to avoid cache-line
thrashing.
- MpscPaddedQueue() - Constructor for class rx.internal.util.MpscPaddedQueue
-
Initializes the empty queue.
- multicast(Func0<? extends Subject<? super T, ? extends TIntermediate>>, Func1<? super Observable<TIntermediate>, ? extends Observable<TResult>>) - Method in class rx.Observable
-
Returns an Observable that emits items produced by multicasting the source Observable within a selector
function.
- multicast(Func0<? extends Subject<? super T, ? extends R>>) - Method in class rx.Observable
-
Returns a
ConnectableObservable
that upon connection causes the source Observable to push results
into the specified subject.
- 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
-
- ObjectPool<T> - Class in rx.internal.util
-
- ObjectPool() - Constructor for class rx.internal.util.ObjectPool
-
- 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.
- Observers() - Constructor for class rx.observers.Observers
-
- offer(E) - Method in class rx.internal.util.MpscPaddedQueue
-
Offer a new value.
- offer(T) - Method in class rx.internal.util.SynchronizedQueue
-
- offer(E) - Method in class rx.internal.util.unsafe.MpmcArrayQueue
-
- offer(E) - Method in class rx.internal.util.unsafe.SpmcArrayQueue
-
- offer(E) - Method in class rx.internal.util.unsafe.SpscArrayQueue
- ofType(Class<R>) - Method in class rx.Observable
-
Filters the items emitted by an Observable, only emitting those of the specified type.
- 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
-
Use this operator when the upstream does not natively support backpressure and you wish to drop
onNext
when unable to handle further events.
- onCompleted() - Method in class rx.internal.operators.BufferUntilSubscriber
-
- onCompleted() - Method in class rx.internal.operators.OperatorGroupByUntil.GroupSubject
-
- onCompleted() - Method in class rx.internal.operators.OperatorReplay.SubjectWrapper
-
- onCompleted() - Method in class rx.internal.util.RxRingBuffer
-
- onCompleted() - Method in interface rx.Observer
-
Notifies the Observer that the
Observable
has finished sending push-based notifications.
- onCompleted() - Method in class rx.observers.EmptyObserver
-
- onCompleted() - Method in class rx.observers.SafeSubscriber
-
- onCompleted() - Method in class rx.observers.SerializedObserver
-
- onCompleted() - Method in class rx.observers.SerializedSubscriber
-
- onCompleted() - Method in class rx.observers.TestObserver
-
- onCompleted() - Method in class rx.observers.TestSubscriber
-
- 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.TestSubject
-
- onCompleted(long) - Method in class rx.subjects.TestSubject
-
Schedule a call to the onCompleted
methods of all of the subscribers to this Subject to begin at
a particular time.
- onCompletedFrom(Observer<T>) - Static method in class rx.functions.Actions
-
Extracts a method reference to the Observer's
onCompleted
method in the
form of an
Action0
.
- onCreate(Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- onError(Throwable) - Method in class rx.internal.operators.BufferUntilSubscriber
-
- onError(Throwable) - Method in class rx.internal.operators.OperatorGroupByUntil.GroupSubject
-
- onError(Throwable) - Method in class rx.internal.operators.OperatorReplay.SubjectWrapper
-
- onError(Throwable) - Method in class rx.internal.util.RxRingBuffer
-
- 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.EmptyObserver
-
- onError(Throwable) - Method in class rx.observers.SafeSubscriber
-
- onError(Throwable) - Method in class rx.observers.SerializedObserver
-
- onError(Throwable) - Method in class rx.observers.SerializedSubscriber
-
- onError(Throwable) - Method in class rx.observers.TestObserver
-
- onError(Throwable) - Method in class rx.observers.TestSubscriber
-
- 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.TestSubject
-
- onError(Throwable, long) - Method in class rx.subjects.TestSubject
-
Schedule a call to the onError
methods of all of the subscribers to this Subject to begin at
a particular time.
- 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
.
- onErrorFrom(Observer<T>) - Static method in class rx.functions.Actions
-
Extracts a method reference to the Observer's
onError
method in the form of an
Action1
.
- 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 class rx.internal.operators.BufferUntilSubscriber
-
- onNext(R) - Method in class rx.internal.operators.OperatorGroupByUntil.GroupSubject
-
- onNext(T) - Method in class rx.internal.operators.OperatorReplay.SubjectWrapper
-
- onNext(Object) - Method in class rx.internal.util.RxRingBuffer
-
- onNext(T) - Method in interface rx.Observer
-
Provides the Observer with a new item to observe.
- onNext(T) - Method in class rx.observers.EmptyObserver
-
- onNext(T) - Method in class rx.observers.SafeSubscriber
-
- onNext(T) - Method in class rx.observers.SerializedObserver
-
- onNext(T) - Method in class rx.observers.SerializedSubscriber
-
- onNext(T) - Method in class rx.observers.TestObserver
-
- onNext(T) - Method in class rx.observers.TestSubscriber
-
- 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.TestSubject
-
- onNext(T, long) - Method in class rx.subjects.TestSubject
-
Emit an item to all of the subscribers to this Subject at a particular time.
- onNextFrom(Observer<T>) - Static method in class rx.functions.Actions
-
Extracts a method reference to the Observer's
onNext
method in the form of an
Action1
.
- 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.
- OnSubscribeAmb<T> - Class in rx.internal.operators
-
Given multiple
Observable
s, propagates the one that first emits an item.
- OnSubscribeCache<T> - Class in rx.internal.operators
-
This method has similar behavior to
Observable.replay()
except that this auto-subscribes
to the source Observable rather than returning a connectable Observable.
- OnSubscribeCache(Observable<? extends T>) - Constructor for class rx.internal.operators.OnSubscribeCache
-
- OnSubscribeCache(Observable<? extends T>, int) - Constructor for class rx.internal.operators.OnSubscribeCache
-
- OnSubscribeCombineLatest<T,R> - Class in rx.internal.operators
-
Returns an Observable that combines the emissions of multiple source observables.
- OnSubscribeCombineLatest(List<? extends Observable<? extends T>>, FuncN<? extends R>) - Constructor for class rx.internal.operators.OnSubscribeCombineLatest
-
- OnSubscribeDefer<T> - Class in rx.internal.operators
-
Do not create the Observable until an Observer subscribes; create a fresh Observable on each
subscription.
- OnSubscribeDefer(Func0<? extends Observable<? extends T>>) - Constructor for class rx.internal.operators.OnSubscribeDefer
-
- OnSubscribeDelay<T> - Class in rx.internal.operators
-
Delays the emission of onNext events by a given amount of time.
- OnSubscribeDelay(Observable<? extends T>, long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OnSubscribeDelay
-
- OnSubscribeDelay.Emitter<T> - Class in rx.internal.operators
-
Emits a value once the call() is invoked.
- OnSubscribeDelay.Emitter(T) - Constructor for class rx.internal.operators.OnSubscribeDelay.Emitter
-
- OnSubscribeDelaySubscription<T> - Class in rx.internal.operators
-
Delays the subscription to the source by the given amount, running on the given scheduler.
- OnSubscribeDelaySubscription(Observable<? extends T>, long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OnSubscribeDelaySubscription
-
- OnSubscribeDelayWithSelector<T,U,V> - Class in rx.internal.operators
-
Delay the subscription and emission of the source items by a per-item observable that fires its first element.
- OnSubscribeDelayWithSelector(Observable<? extends T>, Func1<? super T, ? extends Observable<V>>) - Constructor for class rx.internal.operators.OnSubscribeDelayWithSelector
-
- OnSubscribeDelayWithSelector(Observable<? extends T>, Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>) - Constructor for class rx.internal.operators.OnSubscribeDelayWithSelector
-
- onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- OnSubscribeFromIterable<T> - Class in rx.internal.operators
-
Converts an Iterable
sequence into an Observable
.
- OnSubscribeFromIterable(Iterable<? extends T>) - Constructor for class rx.internal.operators.OnSubscribeFromIterable
-
- OnSubscribeGroupJoin<T1,T2,D1,D2,R> - Class in rx.internal.operators
-
Corrrelates two sequences when they overlap and groups the results.
- OnSubscribeGroupJoin(Observable<T1>, Observable<T2>, Func1<? super T1, ? extends Observable<D1>>, Func1<? super T2, ? extends Observable<D2>>, Func2<? super T1, ? super Observable<T2>, ? extends R>) - Constructor for class rx.internal.operators.OnSubscribeGroupJoin
-
- OnSubscribeJoin<TLeft,TRight,TLeftDuration,TRightDuration,R> - Class in rx.internal.operators
-
Correlates the elements of two sequences based on overlapping durations.
- OnSubscribeJoin(Observable<TLeft>, Observable<TRight>, Func1<TLeft, Observable<TLeftDuration>>, Func1<TRight, Observable<TRightDuration>>, Func2<TLeft, TRight, R>) - Constructor for class rx.internal.operators.OnSubscribeJoin
-
- OnSubscribeMulticastSelector<TInput,TIntermediate,TResult> - Class in rx.internal.operators
-
Returns an observable sequence that contains the elements of a sequence
produced by multicasting the source sequence within a selector function.
- OnSubscribeMulticastSelector(Observable<? extends TInput>, Func0<? extends Subject<? super TInput, ? extends TIntermediate>>, Func1<? super Observable<TIntermediate>, ? extends Observable<TResult>>) - Constructor for class rx.internal.operators.OnSubscribeMulticastSelector
-
- OnSubscribeRange - Class in rx.internal.operators
-
Emit ints from start to end inclusive.
- OnSubscribeRange(int, int) - Constructor for class rx.internal.operators.OnSubscribeRange
-
- OnSubscribeRedo<T> - Class in rx.internal.operators
-
- OnSubscribeRedo.RedoFinite - Class in rx.internal.operators
-
- OnSubscribeRedo.RedoFinite(long) - Constructor for class rx.internal.operators.OnSubscribeRedo.RedoFinite
-
- OnSubscribeRedo.RetryWithPredicate - Class in rx.internal.operators
-
- OnSubscribeRedo.RetryWithPredicate(Func2<Integer, Throwable, Boolean>) - Constructor for class rx.internal.operators.OnSubscribeRedo.RetryWithPredicate
-
- OnSubscribeRefCount<T> - Class in rx.internal.operators
-
Returns an observable sequence that stays connected to the source as long
as there is at least one subscription to the observable sequence.
- OnSubscribeRefCount(ConnectableObservable<? extends T>) - Constructor for class rx.internal.operators.OnSubscribeRefCount
-
- onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- onSubscribeStart(Observable<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
- OnSubscribeTimerOnce - Class in rx.internal.operators
-
Timer that emits a single 0L and completes after the specified time.
- OnSubscribeTimerOnce(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OnSubscribeTimerOnce
-
- OnSubscribeTimerPeriodically - Class in rx.internal.operators
-
Emit 0L after the initial period and ever increasing number after each period.
- OnSubscribeTimerPeriodically(long, long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OnSubscribeTimerPeriodically
-
- OnSubscribeToObservableFuture - Class in rx.internal.operators
-
Converts a Future
into an Observable
.
- OnSubscribeToObservableFuture() - Constructor for class rx.internal.operators.OnSubscribeToObservableFuture
-
- OnSubscribeUsing<T,Resource> - Class in rx.internal.operators
-
Constructs an observable sequence that depends on a resource object.
- OnSubscribeUsing(Func0<Resource>, Func1<? super Resource, ? extends Observable<? extends T>>, Action1<? super Resource>) - Constructor for class rx.internal.operators.OnSubscribeUsing
-
- OperatorAll<T> - Class in rx.internal.operators
-
Returns an Observable that emits a Boolean that indicates whether all items emitted by an
Observable satisfy a condition.
- OperatorAll(Func1<? super T, Boolean>) - Constructor for class rx.internal.operators.OperatorAll
-
- OperatorAny<T> - Class in rx.internal.operators
-
Returns an
Observable
that emits
true
if any element of
an observable sequence satisfies a condition, otherwise
false
.
- OperatorAny(Func1<? super T, Boolean>, boolean) - Constructor for class rx.internal.operators.OperatorAny
-
- OperatorAsObservable<T> - Class in rx.internal.operators
-
Hides the identity of another observable.
- OperatorAsObservable() - Constructor for class rx.internal.operators.OperatorAsObservable
-
- OperatorBufferWithSingleObservable<T,TClosing> - Class in rx.internal.operators
-
This operation takes
values from the specified
Observable
source and stores them in a buffer until the
Observable
constructed using the
Func0
argument, produces a value.
- OperatorBufferWithSingleObservable(Func0<? extends Observable<? extends TClosing>>, int) - Constructor for class rx.internal.operators.OperatorBufferWithSingleObservable
-
- OperatorBufferWithSingleObservable(Observable<? extends TClosing>, int) - Constructor for class rx.internal.operators.OperatorBufferWithSingleObservable
-
- OperatorBufferWithSize<T> - Class in rx.internal.operators
-
This operation takes
values from the specified
Observable
source and stores them in all active chunks until the buffer
contains a specified number of elements.
- OperatorBufferWithSize(int, int) - Constructor for class rx.internal.operators.OperatorBufferWithSize
-
- OperatorBufferWithStartEndObservable<T,TOpening,TClosing> - Class in rx.internal.operators
-
This operation takes
values from the specified
Observable
source and stores them in the currently active chunks.
- OperatorBufferWithStartEndObservable(Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Constructor for class rx.internal.operators.OperatorBufferWithStartEndObservable
-
- OperatorBufferWithTime<T> - Class in rx.internal.operators
-
This operation takes
values from the specified
Observable
source and stores them in a buffer.
- OperatorBufferWithTime(long, long, TimeUnit, int, Scheduler) - Constructor for class rx.internal.operators.OperatorBufferWithTime
-
- OperatorCast<T,R> - Class in rx.internal.operators
-
Converts the elements of an observable sequence to the specified type.
- OperatorCast(Class<R>) - Constructor for class rx.internal.operators.OperatorCast
-
- OperatorConcat<T> - Class in rx.internal.operators
-
Returns an Observable that emits the items emitted by two or more Observables, one after the other.
- OperatorConcat() - Constructor for class rx.internal.operators.OperatorConcat
-
- OperatorDebounceWithSelector<T,U> - Class in rx.internal.operators
-
Delay the emission via another observable if no new source appears in the meantime.
- OperatorDebounceWithSelector(Func1<? super T, ? extends Observable<U>>) - Constructor for class rx.internal.operators.OperatorDebounceWithSelector
-
- OperatorDebounceWithTime<T> - Class in rx.internal.operators
-
This operation filters out events which are published too quickly in succession.
- OperatorDebounceWithTime(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorDebounceWithTime
-
- OperatorDefaultIfEmpty<T> - Class in rx.internal.operators
-
Returns the elements of the specified sequence or the specified default value
in a singleton sequence if the sequence is empty.
- OperatorDefaultIfEmpty(T) - Constructor for class rx.internal.operators.OperatorDefaultIfEmpty
-
- OperatorDematerialize<T> - Class in rx.internal.operators
-
Reverses the effect of
OperatorMaterialize
by transforming the Notification objects
emitted by a source Observable into the items or notifications they represent.
- OperatorDematerialize() - Constructor for class rx.internal.operators.OperatorDematerialize
-
- OperatorDistinct<T,U> - Class in rx.internal.operators
-
Returns an Observable that emits all distinct items emitted by the source.
- OperatorDistinct(Func1<? super T, ? extends U>) - Constructor for class rx.internal.operators.OperatorDistinct
-
- OperatorDistinctUntilChanged<T,U> - Class in rx.internal.operators
-
Returns an Observable that emits all sequentially distinct items emitted by the source.
- OperatorDistinctUntilChanged(Func1<? super T, ? extends U>) - Constructor for class rx.internal.operators.OperatorDistinctUntilChanged
-
- OperatorDoOnEach<T> - Class in rx.internal.operators
-
Converts the elements of an observable sequence to the specified type.
- OperatorDoOnEach(Observer<? super T>) - Constructor for class rx.internal.operators.OperatorDoOnEach
-
- OperatorDoOnSubscribe<T> - Class in rx.internal.operators
-
This operator modifies an
Observable
so a given action is invoked when the
Observable
is subscribed.
- OperatorDoOnSubscribe(Action0) - Constructor for class rx.internal.operators.OperatorDoOnSubscribe
-
Constructs an instance of the operator with the callback that gets invoked when the modified Observable is subscribed
- OperatorDoOnUnsubscribe<T> - Class in rx.internal.operators
-
This operator modifies an
Observable
so a given action is invoked when the
Observable
is unsubscribed.
- OperatorDoOnUnsubscribe(Action0) - Constructor for class rx.internal.operators.OperatorDoOnUnsubscribe
-
Constructs an instance of the operator with the callback that gets invoked when the modified Observable is unsubscribed
- OperatorElementAt<T> - Class in rx.internal.operators
-
Returns the element at a specified index in a sequence.
- OperatorElementAt(int) - Constructor for class rx.internal.operators.OperatorElementAt
-
- OperatorElementAt(int, T) - Constructor for class rx.internal.operators.OperatorElementAt
-
- OperatorFilter<T> - Class in rx.internal.operators
-
Filters an Observable by discarding any items it emits that do not meet some test.
- OperatorFilter(Func1<? super T, Boolean>) - Constructor for class rx.internal.operators.OperatorFilter
-
- OperatorFinally<T> - Class in rx.internal.operators
-
Registers an action to be called after an Observable invokes onComplete
or onError
.
- OperatorFinally(Action0) - Constructor for class rx.internal.operators.OperatorFinally
-
- OperatorGroupBy<T,K,R> - Class in rx.internal.operators
-
Groups the items emitted by an Observable according to a specified criterion, and emits these
grouped items as Observables, one Observable per group.
- OperatorGroupBy(Func1<? super T, ? extends K>) - Constructor for class rx.internal.operators.OperatorGroupBy
-
- OperatorGroupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>) - Constructor for class rx.internal.operators.OperatorGroupBy
-
- OperatorGroupByUntil<T,K,R,D> - Class in rx.internal.operators
-
Groups the elements of an observable sequence according to a specified key selector, value selector and
duration selector function.
- OperatorGroupByUntil(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>, Func1<? super GroupedObservable<K, R>, ? extends Observable<? extends D>>) - Constructor for class rx.internal.operators.OperatorGroupByUntil
-
- OperatorGroupByUntil.GroupSubject<K,R> - Class in rx.internal.operators
-
A grouped observable with subject-like behavior.
- OperatorGroupByUntil.GroupSubject(K, Subject<R, R>) - Constructor for class rx.internal.operators.OperatorGroupByUntil.GroupSubject
-
- OperatorMap<T,R> - Class in rx.internal.operators
-
Applies a function of your choosing to every item emitted by an Observable
, and emits the results of
this transformation as a new Observable
.
- OperatorMap(Func1<? super T, ? extends R>) - Constructor for class rx.internal.operators.OperatorMap
-
- OperatorMapNotification<T,R> - Class in rx.internal.operators
-
Applies a function of your choosing to every item emitted by an Observable
, and emits the results of
this transformation as a new Observable
.
- OperatorMapNotification(Func1<? super T, ? extends R>, Func1<? super Throwable, ? extends R>, Func0<? extends R>) - Constructor for class rx.internal.operators.OperatorMapNotification
-
- OperatorMapPair<T,U,R> - Class in rx.internal.operators
-
An
Observable.Operator
that pairs up items emitted by a source
Observable
with the sequence of items
emitted by the
Observable
that is derived from each item by means of a selector, and emits the
results of this pairing.
- OperatorMapPair(Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>) - Constructor for class rx.internal.operators.OperatorMapPair
-
- OperatorMaterialize<T> - Class in rx.internal.operators
-
Turns all of the notifications from an Observable into
onNext
emissions, and marks
them with their original notification types within
Notification
objects.
- OperatorMaterialize() - Constructor for class rx.internal.operators.OperatorMaterialize
-
- OperatorMerge<T> - Class in rx.internal.operators
-
Flattens a list of
Observable
s into one
Observable
, without any transformation.
- OperatorMerge() - Constructor for class rx.internal.operators.OperatorMerge
-
- OperatorMerge(boolean) - Constructor for class rx.internal.operators.OperatorMerge
-
- OperatorMergeDelayError<T> - Class in rx.internal.operators
-
This behaves like
OperatorMerge
except that if any of the merged Observables notify of
an error via
onError
,
mergeDelayError
will refrain from propagating that error
notification until all of the merged Observables have finished emitting items.
- OperatorMergeDelayError() - Constructor for class rx.internal.operators.OperatorMergeDelayError
-
- OperatorMergeMaxConcurrent<T> - Class in rx.internal.operators
-
Flattens a list of Observables into one Observable sequence, without any transformation.
- OperatorMergeMaxConcurrent(int) - Constructor for class rx.internal.operators.OperatorMergeMaxConcurrent
-
- OperatorMulticast<T,R> - Class in rx.internal.operators
-
Shares a single subscription to a source through a Subject.
- OperatorMulticast(Observable<? extends T>, Func0<? extends Subject<? super T, ? extends R>>) - Constructor for class rx.internal.operators.OperatorMulticast
-
- OperatorObserveOn<T> - Class in rx.internal.operators
-
Delivers events on the specified Scheduler
asynchronously via an unbounded buffer.
- OperatorObserveOn(Scheduler) - Constructor for class rx.internal.operators.OperatorObserveOn
-
- OperatorOnBackpressureBuffer<T> - Class in rx.internal.operators
-
- OperatorOnBackpressureBuffer() - Constructor for class rx.internal.operators.OperatorOnBackpressureBuffer
-
- OperatorOnBackpressureDrop<T> - Class in rx.internal.operators
-
- OperatorOnBackpressureDrop() - Constructor for class rx.internal.operators.OperatorOnBackpressureDrop
-
- OperatorOnErrorFlatMap<T> - Class in rx.internal.operators
-
Allows inserting onNext events into a stream when onError events are received
and continuing the original sequence instead of terminating.
- OperatorOnErrorFlatMap(Func1<OnErrorThrowable, ? extends Observable<? extends T>>) - Constructor for class rx.internal.operators.OperatorOnErrorFlatMap
-
- OperatorOnErrorResumeNextViaFunction<T> - Class in rx.internal.operators
-
Instruct an Observable to pass control to another Observable (the return value of a function)
rather than invoking onError
if it encounters an error.
- OperatorOnErrorResumeNextViaFunction(Func1<Throwable, ? extends Observable<? extends T>>) - Constructor for class rx.internal.operators.OperatorOnErrorResumeNextViaFunction
-
- OperatorOnErrorResumeNextViaObservable<T> - Class in rx.internal.operators
-
Instruct an Observable to pass control to another Observable rather than invoking
onError
if it encounters an error.
- OperatorOnErrorResumeNextViaObservable(Observable<? extends T>) - Constructor for class rx.internal.operators.OperatorOnErrorResumeNextViaObservable
-
- OperatorOnErrorReturn<T> - Class in rx.internal.operators
-
Instruct an Observable to emit a particular item to its Observer's onNext
method
rather than invoking onError
if it encounters an error.
- OperatorOnErrorReturn(Func1<Throwable, ? extends T>) - Constructor for class rx.internal.operators.OperatorOnErrorReturn
-
- OperatorOnExceptionResumeNextViaObservable<T> - Class in rx.internal.operators
-
Instruct an Observable to pass control to another Observable rather than invoking
onError
if it encounters an error of type Exception
.
- OperatorOnExceptionResumeNextViaObservable(Observable<? extends T>) - Constructor for class rx.internal.operators.OperatorOnExceptionResumeNextViaObservable
-
- OperatorReplay - Class in rx.internal.operators
-
Replay with limited buffer and/or time constraints.
- OperatorReplay.SubjectWrapper<T> - Class in rx.internal.operators
-
A subject that wraps another subject.
- OperatorReplay.SubjectWrapper(Observable.OnSubscribe<T>, Subject<T, T>) - Constructor for class rx.internal.operators.OperatorReplay.SubjectWrapper
-
- OperatorRetryWithPredicate<T> - Class in rx.internal.operators
-
- OperatorRetryWithPredicate(Func2<Integer, Throwable, Boolean>) - Constructor for class rx.internal.operators.OperatorRetryWithPredicate
-
- OperatorSampleWithObservable<T,U> - Class in rx.internal.operators
-
Sample with the help of another observable.
- OperatorSampleWithObservable(Observable<U>) - Constructor for class rx.internal.operators.OperatorSampleWithObservable
-
- OperatorSampleWithTime<T> - Class in rx.internal.operators
-
Returns an Observable that emits the results of sampling the items emitted by the source
Observable at a specified time interval.
- OperatorSampleWithTime(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorSampleWithTime
-
- OperatorScan<R,T> - Class in rx.internal.operators
-
Returns an Observable that applies a function to the first item emitted by a source Observable, 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 result of each of these
iterations.
- OperatorScan(R, Func2<R, ? super T, R>) - Constructor for class rx.internal.operators.OperatorScan
-
Applies an accumulator function over an observable sequence and returns each intermediate result with the
specified source and accumulator.
- OperatorScan(Func2<R, ? super T, R>) - Constructor for class rx.internal.operators.OperatorScan
-
Applies an accumulator function over an observable sequence and returns each intermediate result with the
specified source and accumulator.
- OperatorSequenceEqual - Class in rx.internal.operators
-
Returns an
Observable
that emits a single
Boolean
value that indicates whether two source
Observable
s emit sequences of items that are equivalent to each other.
- OperatorSerialize<T> - Class in rx.internal.operators
-
- OperatorSerialize() - Constructor for class rx.internal.operators.OperatorSerialize
-
- OperatorSingle<T> - Class in rx.internal.operators
-
If the Observable completes after emitting a single item that matches a
predicate, return an Observable containing that item.
- OperatorSingle() - Constructor for class rx.internal.operators.OperatorSingle
-
- OperatorSingle(T) - Constructor for class rx.internal.operators.OperatorSingle
-
- OperatorSkip<T> - Class in rx.internal.operators
-
Returns an Observable that skips the first num
items emitted by the source
Observable.
- OperatorSkip(int) - Constructor for class rx.internal.operators.OperatorSkip
-
- OperatorSkipLast<T> - Class in rx.internal.operators
-
Bypasses a specified number of elements at the end of an observable sequence.
- OperatorSkipLast(int) - Constructor for class rx.internal.operators.OperatorSkipLast
-
- OperatorSkipLastTimed<T> - Class in rx.internal.operators
-
Skip delivering values in the time window before the values.
- OperatorSkipLastTimed(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorSkipLastTimed
-
- OperatorSkipTimed<T> - Class in rx.internal.operators
-
Skips elements until a specified time elapses.
- OperatorSkipTimed(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorSkipTimed
-
- OperatorSkipUntil<T,U> - Class in rx.internal.operators
-
Skip elements from the source Observable until the secondary
observable fires an element.
- OperatorSkipUntil(Observable<U>) - Constructor for class rx.internal.operators.OperatorSkipUntil
-
- OperatorSkipWhile<T> - Class in rx.internal.operators
-
Skips any emitted source items as long as the specified condition holds true.
- OperatorSkipWhile(Func2<? super T, Integer, Boolean>) - Constructor for class rx.internal.operators.OperatorSkipWhile
-
- OperatorSubscribeOn<T> - Class in rx.internal.operators
-
Subscribes Observers on the specified Scheduler
.
- OperatorSubscribeOn(Scheduler) - Constructor for class rx.internal.operators.OperatorSubscribeOn
-
- OperatorSwitch<T> - Class in rx.internal.operators
-
Transforms an Observable that emits Observables into a single Observable that
emits the items emitted by the most recently published of those Observables.
- OperatorSwitch() - Constructor for class rx.internal.operators.OperatorSwitch
-
- OperatorTake<T> - Class in rx.internal.operators
-
An Observable
that emits the first num
items emitted by the source Observable
.
- OperatorTake(int) - Constructor for class rx.internal.operators.OperatorTake
-
- OperatorTakeLast<T> - Class in rx.internal.operators
-
Returns an Observable that emits the last count
items emitted by the source Observable.
- OperatorTakeLast(int) - Constructor for class rx.internal.operators.OperatorTakeLast
-
- OperatorTakeLastTimed<T> - Class in rx.internal.operators
-
Returns an Observable that emits the last count
items emitted by the source Observable.
- OperatorTakeLastTimed(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorTakeLastTimed
-
- OperatorTakeLastTimed(int, long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorTakeLastTimed
-
- OperatorTakeTimed<T> - Class in rx.internal.operators
-
Takes values from the source until the specific time ellapses.
- OperatorTakeTimed(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorTakeTimed
-
- OperatorTakeUntil<T,E> - Class in rx.internal.operators
-
Returns an Observable that emits the items from the source Observable until another Observable
emits an item.
- OperatorTakeUntil(Observable<? extends E>) - Constructor for class rx.internal.operators.OperatorTakeUntil
-
- OperatorTakeWhile<T> - Class in rx.internal.operators
-
Returns an Observable that emits items emitted by the source Observable as long as a specified
condition is true.
- OperatorTakeWhile(Func1<? super T, Boolean>) - Constructor for class rx.internal.operators.OperatorTakeWhile
-
- OperatorTakeWhile(Func2<? super T, ? super Integer, Boolean>) - Constructor for class rx.internal.operators.OperatorTakeWhile
-
- OperatorThrottleFirst<T> - Class in rx.internal.operators
-
Throttle by windowing a stream and returning the first value in each window.
- OperatorThrottleFirst(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorThrottleFirst
-
- OperatorTimeInterval<T> - Class in rx.internal.operators
-
Records the time interval between consecutive elements in an observable sequence.
- OperatorTimeInterval(Scheduler) - Constructor for class rx.internal.operators.OperatorTimeInterval
-
- OperatorTimeout<T> - Class in rx.internal.operators
-
Applies a timeout policy for each element in the observable sequence, using
the specified scheduler to run timeout timers.
- OperatorTimeout(long, TimeUnit, Observable<? extends T>, Scheduler) - Constructor for class rx.internal.operators.OperatorTimeout
-
- OperatorTimeoutWithSelector<T,U,V> - Class in rx.internal.operators
-
Returns an Observable that mirrors the source Observable.
- OperatorTimeoutWithSelector(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>, Observable<? extends T>) - Constructor for class rx.internal.operators.OperatorTimeoutWithSelector
-
- OperatorTimestamp<T> - Class in rx.internal.operators
-
Wraps each item emitted by a source
Observable
in a
Timestamped
object.
- OperatorTimestamp(Scheduler) - Constructor for class rx.internal.operators.OperatorTimestamp
-
- OperatorToMap<T,K,V> - Class in rx.internal.operators
-
Maps the elements of the source observable into a java.util.Map instance and
emits that once the source observable completes.
- OperatorToMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Constructor for class rx.internal.operators.OperatorToMap
-
ToMap with key selector, value selector and default HashMap factory.
- OperatorToMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, V>>) - Constructor for class rx.internal.operators.OperatorToMap
-
ToMap with key selector, value selector and custom Map factory.
- OperatorToMap.DefaultToMapFactory<K,V> - Class in rx.internal.operators
-
The default map factory.
- OperatorToMap.DefaultToMapFactory() - Constructor for class rx.internal.operators.OperatorToMap.DefaultToMapFactory
-
- OperatorToMultimap<T,K,V> - Class in rx.internal.operators
-
Maps the elements of the source observable into a multimap
(Map<K, Collection<V>>) where each
key entry has a collection of the source's values.
- OperatorToMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Constructor for class rx.internal.operators.OperatorToMultimap
-
ToMultimap with key selector, custom value selector,
default HashMap factory and default ArrayList collection factory.
- OperatorToMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>) - Constructor for class rx.internal.operators.OperatorToMultimap
-
ToMultimap with key selector, custom value selector,
custom Map factory and default ArrayList collection factory.
- OperatorToMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>, Func1<? super K, ? extends Collection<V>>) - Constructor for class rx.internal.operators.OperatorToMultimap
-
ToMultimap with key selector, custom value selector,
custom Map factory and custom collection factory.
- OperatorToMultimap.DefaultMultimapCollectionFactory<K,V> - Class in rx.internal.operators
-
The default collection factory for a key in the multimap returning
an ArrayList independent of the key.
- OperatorToMultimap.DefaultMultimapCollectionFactory() - Constructor for class rx.internal.operators.OperatorToMultimap.DefaultMultimapCollectionFactory
-
- OperatorToMultimap.DefaultToMultimapFactory<K,V> - Class in rx.internal.operators
-
The default multimap factory returning a HashMap.
- OperatorToMultimap.DefaultToMultimapFactory() - Constructor for class rx.internal.operators.OperatorToMultimap.DefaultToMultimapFactory
-
- OperatorToObservableList<T> - Class in rx.internal.operators
-
Returns an Observable
that emits a single item, a list composed of all the items emitted by the
source Observable
.
- OperatorToObservableList() - Constructor for class rx.internal.operators.OperatorToObservableList
-
- OperatorToObservableSortedList<T> - Class in rx.internal.operators
-
Return an Observable
that emits the items emitted by the source Observable
, in a sorted order
(each item emitted by the Observable
must implement Comparable
with respect to all other
items in the sequence, or you must pass in a sort function).
- OperatorToObservableSortedList() - Constructor for class rx.internal.operators.OperatorToObservableSortedList
-
- OperatorToObservableSortedList(Func2<? super T, ? super T, Integer>) - Constructor for class rx.internal.operators.OperatorToObservableSortedList
-
- OperatorUnsubscribeOn<T> - Class in rx.internal.operators
-
Unsubscribes on the specified Scheduler.
- OperatorUnsubscribeOn(Scheduler) - Constructor for class rx.internal.operators.OperatorUnsubscribeOn
-
- OperatorWindowWithObservable<T,U> - Class in rx.internal.operators
-
Creates non-overlapping windows of items where each window is terminated by
an event from a secondary observable and a new window is started immediately.
- OperatorWindowWithObservable(Func0<? extends Observable<? extends U>>) - Constructor for class rx.internal.operators.OperatorWindowWithObservable
-
- OperatorWindowWithObservable(Observable<U>) - Constructor for class rx.internal.operators.OperatorWindowWithObservable
-
- OperatorWindowWithSize<T> - Class in rx.internal.operators
-
Creates windows of values into the source sequence with skip frequency and size bounds.
- OperatorWindowWithSize(int, int) - Constructor for class rx.internal.operators.OperatorWindowWithSize
-
- OperatorWindowWithStartEndObservable<T,U,V> - Class in rx.internal.operators
-
Creates potentially overlapping windows of the source items where each window is
started by a value emitted by an observable and closed when an associated Observable emits
a value or completes.
- OperatorWindowWithStartEndObservable(Observable<? extends U>, Func1<? super U, ? extends Observable<? extends V>>) - Constructor for class rx.internal.operators.OperatorWindowWithStartEndObservable
-
- OperatorWindowWithTime<T> - Class in rx.internal.operators
-
Creates windows of values into the source sequence with timed window creation, length and size bounds.
- OperatorWindowWithTime(long, long, TimeUnit, int, Scheduler) - Constructor for class rx.internal.operators.OperatorWindowWithTime
-
- OperatorZip<R> - Class in rx.internal.operators
-
Returns an Observable that emits the results of a function applied to sets of items emitted, in
sequence, by two or more other Observables.
- OperatorZip(FuncN<? extends R>) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZip(Func2) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZip(Func3) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZip(Func4) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZip(Func5) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZip(Func6) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZip(Func7) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZip(Func8) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZip(Func9) - Constructor for class rx.internal.operators.OperatorZip
-
- OperatorZipIterable<T1,T2,R> - Class in rx.internal.operators
-
- OperatorZipIterable(Iterable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Constructor for class rx.internal.operators.OperatorZipIterable
-
- 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.
- redo(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- reduce(Func2<T, T, T>) - Method in class rx.Observable
-
Returns an Observable that applies a function of your choosing 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 function of your choosing 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.
- release() - Method in class rx.internal.util.RxRingBuffer
-
- releaseToPool() - Method in class rx.internal.util.IndexedRingBuffer
-
This resets the arrays, nulls out references and returns it to the pool.
- remove(int) - Method in class rx.internal.util.IndexedRingBuffer
-
- remove(int) - Method in class rx.internal.util.SubscriptionIndexedRingBuffer
-
Uses the Node received from `add` to remove this Subscription.
- remove(Subscription) - Method in class rx.internal.util.SubscriptionRandomList
-
- remove(Object) - Method in class rx.internal.util.SynchronizedQueue
-
- remove() - Method in class rx.internal.util.SynchronizedQueue
-
- remove(Subscription) - Method in class rx.subscriptions.CompositeSubscription
-
- removeAll(Collection<?>) - Method in class rx.internal.util.SynchronizedQueue
-
- removeSilently(int) - Method in class rx.internal.util.SubscriptionIndexedRingBuffer
-
Uses the Node received from `add` to remove this Subscription.
- repeat(Observable<T>) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- repeat(Observable<T>, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- repeat(Observable<T>, long) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- repeat(Observable<T>, long, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- repeat(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- repeat(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- 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 Notification<?>>, ? 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 Notification<?>>, ? 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
-
- resultSelector - Variable in class rx.internal.operators.OnSubscribeGroupJoin
-
- retainAll(Collection<?>) - Method in class rx.internal.util.SynchronizedQueue
-
- retry(Observable<T>) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- retry(Observable<T>, long) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- retry(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- retry(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
-
- 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 Notification<?>>, ? 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 Notification<?>>, ? 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
.
- returnNull() - Static method in class rx.functions.Functions
-
Returns a function that merely returns null
, without side effects.
- returnObject(T) - Method in class rx.internal.util.ObjectPool
-
Returns object back to the pool.
- right - Variable in class rx.internal.operators.OnSubscribeGroupJoin
-
- rightDuration - Variable in class rx.internal.operators.OnSubscribeGroupJoin
-
- roundToPowerOfTwo(int) - Static method in class rx.internal.util.unsafe.Pow2
-
Find the next larger positive power of two value up from the given value.
- run() - Method in class rx.internal.schedulers.ScheduledAction
-
- rx - package rx
-
Rx Observables
- rx.exceptions - package rx.exceptions
-
- rx.functions - package rx.functions
-
- rx.internal.operators - package rx.internal.operators
-
Operators that allow composing Observables to transform and
manipulate data in an asynchronous, functional and thread-safe manner.
- rx.internal.schedulers - package rx.internal.schedulers
-
- rx.internal.util - package rx.internal.util
-
- rx.internal.util.unsafe - package rx.internal.util.unsafe
-
- 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
-
- RxJavaErrorHandlerDefault - Class in rx.plugins
-
- RxJavaErrorHandlerDefault() - Constructor for class rx.plugins.RxJavaErrorHandlerDefault
-
- 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
-
- RxRingBuffer - Class in rx.internal.util
-
This assumes Spsc or Spmc usage.
- RxThreadFactory - Class in rx.internal.util
-
- RxThreadFactory(String) - Constructor for class rx.internal.util.RxThreadFactory
-
- SafeSubscriber<T> - Class in rx.observers
-
Wrapper around Observer
that ensures compliance 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.
- ScalarSynchronousObservable<T> - Class in rx.internal.util
-
- ScalarSynchronousObservable(T) - Constructor for class rx.internal.util.ScalarSynchronousObservable
-
- scan(Func2<T, T, T>) - Method in class rx.Observable
-
Returns an Observable that applies a function of your choosing 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 function of your choosing 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.internal.schedulers.NewThreadWorker
-
- schedule(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.NewThreadWorker
-
- 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.
- scheduleActual(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.NewThreadWorker
-
- ScheduledAction - Class in rx.internal.schedulers
-
A Runnable
that executes an Action0
and can be cancelled.
- ScheduledAction(Action0) - Constructor for class rx.internal.schedulers.ScheduledAction
-
- schedulePeriodically(Action0, long, long, TimeUnit) - Method in class rx.Scheduler.Worker
-
Schedules a cancelable action to be executed periodically.
- Scheduler - Class in rx
-
Represents 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.
- sequenceBuffer - Variable in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
-
- sequenceEqual(Observable<? extends T>, Observable<? extends T>, Func2<? super T, ? super T, Boolean>) - Static method in class rx.internal.operators.OperatorSequenceEqual
-
Tests whether two Observable
sequences are identical, emitting true
if both sequences
complete without differing, and false
if the two sequences diverge at any point.
- 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
-
- 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
-
- shutdown() - Method in class rx.internal.util.ObjectPool
-
Shutdown this pool.
- 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.
- SIZE - Static variable in class rx.internal.util.RxRingBuffer
-
- size() - Method in class rx.internal.util.SynchronizedQueue
-
- size() - Method in class rx.internal.util.unsafe.MpmcArrayQueue
-
- size() - Method in class rx.internal.util.unsafe.SpmcArrayQueue
-
- size() - Method in class rx.internal.util.unsafe.SpscArrayQueue
-
- 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.
- skipWhileWithIndex(Func2<? super T, Integer, 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.
- soElement(long, E) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
An ordered store(store + StoreStore barrier) of an element to a given offset
- soElement(E[], long, E) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
An ordered store(store + StoreStore barrier) of an element to a given offset
- soSequence(long[], long, long) - Method in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
-
- source - Variable in class rx.internal.operators.OnSubscribeCache
-
- SPARSE_SHIFT - Static variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
- spElement(long, E) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A plain store (no ordering/fences) of an element to a given offset
- spElement(E[], long, E) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A plain store (no ordering/fences) of an element to a given offset
- SpmcArrayQueue<E> - Class in rx.internal.util.unsafe
-
- SpmcArrayQueue(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueue
-
- SpscArrayQueue<E> - Class in rx.internal.util.unsafe
-
A Single-Producer-Single-Consumer queue backed by a pre-allocated buffer. This implementation is a mashup of the
Fast Flow algorithm with an optimization of the offer
method taken from the
BQueue algorithm (a
variation on Fast Flow).
For convenience the relevant papers are available in the resources folder:
2010 - Pisa - SPSC Queues on Shared Cache Multi-Core Systems.pdf
2012 - Junchang- BQueue- Efficient and Practical Queuing.pdf
This implementation is wait free.
- SpscArrayQueue(int) - Constructor for class rx.internal.util.unsafe.SpscArrayQueue
-
- 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
-
- subscriberOf(Observable<T>) - Static method in class rx.internal.operators.OperatorReplay
-
Return an OnSubscribeFunc which delegates the subscription to the given observable.
- Subscribers - Class in rx.observers
-
Helper methods and utilities for creating and working with
Subscriber
objects.
- Subscription - Interface in rx
-
- SubscriptionIndexedRingBuffer<T extends Subscription> - Class in rx.internal.util
-
Similar to CompositeSubscription but giving extra access to internals so we can reuse a datastructure.
- SubscriptionIndexedRingBuffer() - Constructor for class rx.internal.util.SubscriptionIndexedRingBuffer
-
- SubscriptionIndexedRingBuffer(T...) - Constructor for class rx.internal.util.SubscriptionIndexedRingBuffer
-
- SubscriptionList - Class in rx.internal.util
-
Subscription that represents a group of Subscriptions that are unsubscribed together.
- SubscriptionList() - Constructor for class rx.internal.util.SubscriptionList
-
- SubscriptionList(Subscription...) - Constructor for class rx.internal.util.SubscriptionList
-
- SubscriptionRandomList<T extends Subscription> - Class in rx.internal.util
-
Subscription that represents a group of Subscriptions that are unsubscribed together.
- SubscriptionRandomList() - Constructor for class rx.internal.util.SubscriptionRandomList
-
- SubscriptionRandomList(T...) - Constructor for class rx.internal.util.SubscriptionRandomList
-
- Subscriptions - Class in rx.subscriptions
-
Helper methods and utilities for creating and working with
Subscription
objects
- Subscriptions() - Constructor for class rx.subscriptions.Subscriptions
-
- 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.
- SynchronizedQueue<T> - Class in rx.internal.util
-
Intended for use when the `sun.misc.Unsafe` implementations can't be used.
- SynchronizedQueue() - Constructor for class rx.internal.util.SynchronizedQueue
-
- SynchronizedQueue(int) - Constructor for class rx.internal.util.SynchronizedQueue
-
- SynchronizedSubscription - Class in rx.internal.util
-
- SynchronizedSubscription(Subscription) - Constructor for class rx.internal.util.SynchronizedSubscription
-
- 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.
- takeWhileWithIndex(Func2<? super T, ? super Integer, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits the items emitted by a source Observable so long as a given predicate
remains true, where the predicate operates on both the item and its index relative to the complete
sequence of emitted items.
- terminalState - Variable in class rx.internal.util.RxRingBuffer
-
We store the terminal state separately so it doesn't count against the size.
- 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
-
Subscriber usable 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
-
- toArray() - Method in class rx.internal.util.SynchronizedQueue
-
- toArray(R[]) - Method in class rx.internal.util.SynchronizedQueue
-
- 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(Observable<? extends T>) - Static method in class rx.internal.operators.BlockingOperatorToFuture
-
Returns a Future that expects a single item from the observable.
- 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
.
- toIterator(Observable<? extends T>) - Static method in class rx.internal.operators.BlockingOperatorToIterator
-
Returns an iterator that iterates all values of the observable.
- toList() - Method in class rx.Observable
-
Returns an Observable that emits a single item, a list composed of all the items emitted by the source
Observable.
- toMap(Func1<? super T, ? extends K>) - Method in class rx.Observable
-
Returns an Observable that emits a single HashMap containing all items emitted by the source Observable,
mapped by the keys returned by a specified keySelector
function.
- toMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Method in class rx.Observable
-
Returns an Observable that emits a single HashMap containing values corresponding to items emitted by the
source Observable, mapped by the keys returned by a specified keySelector
function.
- toMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, V>>) - Method in class rx.Observable
-
Returns an Observable that emits a single Map, returned by a specified mapFactory
function, that
contains keys and values extracted from the items emitted by the source Observable.
- toMultimap(Func1<? super T, ? extends K>) - Method in class rx.Observable
-
Returns an Observable that emits a single HashMap that contains an ArrayList of items emitted by the
source Observable keyed by a specified keySelector
function.
- toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Method in class rx.Observable
-
Returns an Observable that emits a single HashMap that contains an ArrayList of values extracted by a
specified valueSelector
function from items emitted by the source Observable, keyed by a
specified keySelector
function.
- toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>) - Method in class rx.Observable
-
Returns an Observable that emits a single Map, returned by a specified mapFactory
function, that
contains an ArrayList of values, extracted by a specified valueSelector
function from items
emitted by the source Observable and keyed by the keySelector
function.
- toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>, Func1<? super K, ? extends Collection<V>>) - Method in class rx.Observable
-
Returns an Observable that emits a single Map, returned by a specified mapFactory
function, that
contains a custom collection of values, extracted by a specified valueSelector
function from
items emitted by the source Observable, and keyed by the keySelector
function.
- toObservable() - Method in class rx.internal.operators.OperatorGroupByUntil.GroupSubject
-
- toObservableFuture(Future<? extends T>) - Static method in class rx.internal.operators.OnSubscribeToObservableFuture
-
- toObservableFuture(Future<? extends T>, long, TimeUnit) - Static method in class rx.internal.operators.OnSubscribeToObservableFuture
-
- toPredicate2(Func1<? super T, Boolean>) - Static method in class rx.internal.operators.OperatorSkipWhile
-
Convert to Func2 type predicate.
- 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.internal.util.SynchronizedQueue
-
- 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.