RxJava


A B C D E F G H I J K L M N O P Q R S T U V W Z _

A

accept(Observer<? super T>) - Method in class rx.Notification
 
accept(Observer<? super T>, Object) - Method in class rx.operators.NotificationLite
Unwraps the lite notification and calls the appropriate method on the Observer.
Action - Interface in rx.functions
All Action interfaces extend from this.
Action - Interface in rx.util.functions
Deprecated.  
Action0 - Interface in rx.functions
 
Action0 - Interface in rx.util.functions
Deprecated.  
Action1<T1> - Interface in rx.functions
 
Action1<T1> - Interface in rx.util.functions
Deprecated.  
Action2<T1,T2> - Interface in rx.functions
 
Action2<T1,T2> - Interface in rx.util.functions
Deprecated.  
Action3<T1,T2,T3> - Interface in rx.functions
 
Action3<T1,T2,T3> - Interface in rx.util.functions
Deprecated.  
Action4<T1,T2,T3,T4> - Interface in rx.functions
A four-argument action.
Action4<T1,T2,T3,T4> - Interface in rx.util.functions
Deprecated.  
Action5<T1,T2,T3,T4,T5> - Interface in rx.functions
A five-argument action.
Action5<T1,T2,T3,T4,T5> - Interface in rx.util.functions
Deprecated.  
Action6<T1,T2,T3,T4,T5,T6> - Interface in rx.functions
A six-argument action.
Action6<T1,T2,T3,T4,T5,T6> - Interface in rx.util.functions
Deprecated.  
Action7<T1,T2,T3,T4,T5,T6,T7> - Interface in rx.functions
A seven-argument action.
Action7<T1,T2,T3,T4,T5,T6,T7> - Interface in rx.util.functions
Deprecated.  
Action8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in rx.functions
An eight-argument action.
Action8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in rx.util.functions
Deprecated.  
Action9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Interface in rx.functions
A nine-argument action.
Action9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Interface in rx.util.functions
Deprecated.  
ActionN - Interface in rx.functions
A vector-argument action.
ActionN - Interface in rx.util.functions
Deprecated.  
Actions - Class in rx.functions
Utility class for the Action interfaces.
Actions - Class in rx.util.functions
Deprecated.  
activate(Map<Object, JoinObserver>, Observer<R>, Action1<ActivePlan0>) - Method in class rx.joins.Plan0
 
activate(Map<Object, JoinObserver>, Observer<R>, Action1<ActivePlan0>) - Method in class rx.joins.Plan1
 
activate(Map<Object, JoinObserver>, Observer<R>, Action1<ActivePlan0>) - Method in class rx.joins.Plan2
 
activate(Map<Object, JoinObserver>, Observer<R>, Action1<ActivePlan0>) - Method in class rx.joins.Plan3
 
ActivePlan0 - Class in rx.joins
Represents an activated plan.
ActivePlan0() - Constructor for class rx.joins.ActivePlan0
 
ActivePlan1<T1> - Class in rx.joins
Represents an active plan.
ActivePlan1(JoinObserver1<T1>, Action1<T1>, Action0) - Constructor for class rx.joins.ActivePlan1
 
ActivePlan2<T1,T2> - Class in rx.joins
Represents an active plan.
ActivePlan2(JoinObserver1<T1>, JoinObserver1<T2>, Action2<T1, T2>, Action0) - Constructor for class rx.joins.ActivePlan2
 
ActivePlan3<T1,T2,T3> - Class in rx.joins
Represents an active plan.
ActivePlan3(JoinObserver1<T1>, JoinObserver1<T2>, JoinObserver1<T3>, Action3<T1, T2, T3>, Action0) - Constructor for class rx.joins.ActivePlan3
 
add(T) - Method in class rx.operators.OperationReplay.VirtualArrayList
 
add(T) - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
add(T) - Method in interface rx.operators.OperationReplay.VirtualList
Add an element to the list.
add(Subscription) - Method in class rx.Subscriber
Used to register an unsubscribe callback.
add(Subscription) - Method in class rx.subscriptions.CompositeSubscription
 
addActivePlan(ActivePlan0) - Method in class rx.joins.JoinObserver1
 
addCause(Throwable, Throwable) - Static method in class rx.exceptions.Exceptions
 
addJoinObserver(JoinObserver) - Method in class rx.joins.ActivePlan0
 
addValueAsLastCause(Throwable, Object) - Static method in exception rx.exceptions.OnErrorThrowable
Adds the given value as the final cause of the given Throwable wrapped in OnNextValue RuntimeException..
advanceTimeBy(long, TimeUnit) - Method in class rx.schedulers.TestScheduler
 
advanceTimeTo(long, TimeUnit) - Method in class rx.schedulers.TestScheduler
 
aggregate(Func2<T, T, T>) - Method in class rx.Observable
Deprecated. use Observable.reduce(Func2)
aggregate(R, Func2<R, ? super T, R>) - Method in class rx.Observable
Deprecated. use Observable.reduce(Object, Func2)
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.
all(Observable<? extends T>, Func1<? super T, Boolean>) - Static method in class rx.operators.OperationAll
 
alwaysFalse() - Static method in class rx.functions.Functions
 
alwaysFalse() - Static method in class rx.util.functions.Functions
Deprecated.  
alwaysTrue() - Static method in class rx.functions.Functions
 
alwaysTrue() - Static method in class rx.util.functions.Functions
Deprecated.  
amb(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Mirror 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, mirror 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, mirror 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, mirror 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, mirror 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, mirror 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, mirror 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, mirror 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, mirror the one that first emits an item.
amb(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.operators.OperatorAmb
 
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.operators.OperatorAmb
 
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.operators.OperatorAmb
 
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.operators.OperatorAmb
 
amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.operators.OperatorAmb
 
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.operators.OperatorAmb
 
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.operators.OperatorAmb
 
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.operators.OperatorAmb
 
amb(Iterable<? extends Observable<? extends T>>) - Static method in class rx.operators.OperatorAmb
 
and(Observable<T3>) - Method in class rx.joins.Pattern2
Creates a pattern that matches when all three observable sequences have an available element.
and(Observable<T2>) - Method in class rx.Observable
Returns a Pattern that matches when both Observables emit an item.
and(Observable<T1>, Observable<T2>) - Static method in class rx.operators.OperationJoinPatterns
Creates a pattern that matches when both observable sequences have an available element.
any(Observable<? extends T>) - Static method in class rx.operators.OperationAny
Returns an Observable that emits true if the source Observable is not empty, otherwise false.
any(Observable<? extends T>, Func1<? super T, Boolean>) - Static method in class rx.operators.OperationAny
Returns an Observable that emits true if any element of the source Observable satisfies the given condition, otherwise false.
asObservable() - Method in class rx.Observable
Hides the identity of this Observable.
assertReceivedOnNext(List<T>) - Method in class rx.observers.TestObserver
 
assertReceivedOnNext(List<T>) - Method in class rx.observers.TestSubscriber
 
assertTerminalEvent() - Method in class rx.observers.TestObserver
Assert that a single terminal event occurred, either onCompleted or onError.
assertTerminalEvent() - Method in class rx.observers.TestSubscriber
Assert that a single terminal event occurred, either onCompleted or onError.
assertUnsubscribed() - Method in class rx.observers.TestSubscriber
 
AsyncSubject<T> - Class in rx.subjects
Subject that publishes only the last event to each Observer that has subscribed when the sequence completes.
AsyncSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>, AtomicReference<Notification<T>>) - Constructor for class rx.subjects.AsyncSubject
 
average(Observable<Integer>) - Static method in class rx.Observable
Deprecated. use Observable.averageInteger(rx.Observable)
average(Observable<Integer>) - Static method in class rx.operators.OperationAverage
 
averageDouble(Observable<Double>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
averageDouble(Func1<? super T, Double>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
averageDoubles(Observable<Double>) - Static method in class rx.operators.OperationAverage
 
averageFloat(Observable<Float>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
averageFloat(Func1<? super T, Float>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
averageFloats(Observable<Float>) - Static method in class rx.operators.OperationAverage
 
averageInteger(Observable<Integer>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
averageInteger(Func1<? super T, Integer>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
averageLong(Observable<Long>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
averageLong(Func1<? super T, Long>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
averageLongs(Observable<Long>) - Static method in class rx.operators.OperationAverage
 
awaitTerminalEvent() - Method in class rx.observers.TestSubscriber
 
awaitTerminalEvent(long, TimeUnit) - Method in class rx.observers.TestSubscriber
 
awaitTerminalEventAndUnsubscribeOnTimeout(long, TimeUnit) - Method in class rx.observers.TestSubscriber
 

B

BehaviorSubject<T> - Class in rx.subjects
Subject that publishes the most recent and all subsequent events to each subscribed Observer.
BehaviorSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>, AtomicReference<Notification<T>>) - Constructor for class rx.subjects.BehaviorSubject
 
BlockingObservable<T> - Class in rx.observables
An extension of Observable that provides blocking operators.
BooleanSubscription - Class in rx.subscriptions
Subscription that can be checked for status such as in a loop inside an Observable to exit the loop if unsubscribed.
BooleanSubscription() - Constructor for class rx.subscriptions.BooleanSubscription
 
buffer(Func0<? extends Observable<? extends TClosing>>) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(int) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(int, int) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, TimeUnit, int) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, TimeUnit, int, Scheduler) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Method in class rx.Observable
Returns an Observable that emits buffers of items it collects from the source Observable.
buffer(Observable<B>) - Method in class rx.Observable
Returns an Observable that emits non-overlapping buffered items from the source Observable each time the specified boundary Observable emits an item.
buffer(Observable<B>, int) - Method in class rx.Observable
Returns an Observable that emits non-overlapping buffered items from the source Observable each time the specified boundary Observable emits an item.
buffer(Observable<T>, Func0<? extends Observable<? extends TClosing>>) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, int) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, int, int) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, long, TimeUnit) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, long, TimeUnit, int) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, long, TimeUnit, int, Scheduler) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, long, long, TimeUnit) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, long, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
BufferUntilSubscriber<T> - Class in rx.operators
A solution to the "time gap" problem that occurs with `groupBy` and `pivot` => https://github.com/Netflix/RxJava/issues/844 This currently has temporary unbounded buffers.
bufferWithBoundaryObservable(Observable<? extends T>, Observable<B>) - Static method in class rx.operators.OperationBuffer
Create a buffer operator with the given observable sequence as the buffer boundary.
bufferWithBoundaryObservable(Observable<? extends T>, Observable<B>, int) - Static method in class rx.operators.OperationBuffer
Create a buffer operator with the given observable sequence as the buffer boundary and with the given initial capacity for buffers.

C

cache() - Method in class rx.Observable
This method has similar behavior to Observable.replay() except that this auto-subscribes to the source Observable rather than returning a ConnectableObservable.
cache(Observable<? extends T>) - Static method in class rx.operators.OperationCache
 
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.operators.OnSubscribeFromIterable
 
call(Subscriber<? super Integer>) - Method in class rx.operators.OnSubscribeRange
 
call() - Method in class rx.operators.OperationToMap.DefaultToMapFactory
 
call(K) - Method in class rx.operators.OperationToMultimap.DefaultMultimapCollectionFactory
 
call() - Method in class rx.operators.OperationToMultimap.DefaultToMultimapFactory
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorAmb
 
call(Subscriber<? super R>) - Method in class rx.operators.OperatorCast
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorDoOnEach
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorElementAt
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorFilter
 
call(Subscriber<? super GroupedObservable<K, T>>) - Method in class rx.operators.OperatorGroupBy
 
call(Subscriber<? super R>) - Method in class rx.operators.OperatorMap
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorMerge
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorObserveOn
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorObserveOnBounded
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorOnErrorFlatMap
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorOnErrorResumeNextViaFunction
 
call(Subscriber<? super R>) - Method in class rx.operators.OperatorParallel
 
call(Subscriber<? super GroupedObservable<K2, GroupedObservable<K1, T>>>) - Method in class rx.operators.OperatorPivot
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorRepeat
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorRetry
 
call(Subscriber<? super R>) - Method in class rx.operators.OperatorScan
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorSerialize
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorSkip
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorSkipWhile
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorSubscribeOn
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorSynchronize
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorTake
 
call(Subscriber<? super Timestamped<T>>) - Method in class rx.operators.OperatorTimestamp
 
call(Subscriber<? super List<T>>) - Method in class rx.operators.OperatorToObservableList
 
call(Subscriber<? super List<T>>) - Method in class rx.operators.OperatorToObservableSortedList
 
call(Subscriber<? super T>) - Method in class rx.operators.OperatorUnsubscribeOn
 
call(Subscriber<? super R>) - Method in class rx.operators.OperatorZip
 
call(Subscriber<? super R>) - Method in class rx.operators.OperatorZipIterable
 
call(Object...) - Method in interface rx.util.functions.FuncN
Deprecated.  
call(T) - Method in class rx.util.functions.Not
Deprecated.  
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.
ChunkedOperation - Class in rx.operators
The base class for operations that break observables into "chunks".
ChunkedOperation() - Constructor for class rx.operators.ChunkedOperation
 
ChunkedOperation.Chunk<T,C> - Class in rx.operators
This class represents a single chunk: A sequence of recorded values.
ChunkedOperation.Chunk() - Constructor for class rx.operators.ChunkedOperation.Chunk
 
ChunkedOperation.ChunkCreator - Interface in rx.operators
This interface defines a way which specifies when to create a new internal ChunkedOperation.Chunk object.
ChunkedOperation.ChunkObserver<T,C> - Class in rx.operators
This ChunkedOperation.ChunkObserver object can be constructed using a ChunkedOperation.Chunks object, a Observer object, and a ChunkedOperation.ChunkCreator object.
ChunkedOperation.ChunkObserver(ChunkedOperation.Chunks<T, C>, Observer<? super C>, ChunkedOperation.ChunkCreator) - Constructor for class rx.operators.ChunkedOperation.ChunkObserver
 
ChunkedOperation.Chunks<T,C> - Class in rx.operators
This class represents an object which contains and manages multiple ChunkedOperation.Chunk objects.
ChunkedOperation.Chunks(Observer<? super C>, Func0<? extends ChunkedOperation.Chunk<T, C>>) - Constructor for class rx.operators.ChunkedOperation.Chunks
Constructs a new ChunkedOperation.Chunks object for the specified Observer.
ChunkedOperation.NonOverlappingChunks<T,C> - Class in rx.operators
This class is an extension on the ChunkedOperation.Chunks class which only supports one active (not yet emitted) internal ChunkedOperation.Chunks object.
ChunkedOperation.NonOverlappingChunks(Observer<? super C>, Func0<? extends ChunkedOperation.Chunk<T, C>>) - Constructor for class rx.operators.ChunkedOperation.NonOverlappingChunks
 
ChunkedOperation.ObservableBasedMultiChunkCreator<T,C,TOpening,TClosing> - Class in rx.operators
This ChunkedOperation.ChunkCreator creates a new ChunkedOperation.Chunk whenever it receives an object from the provided chunkOpenings Observable, and closes the corresponding ChunkedOperation.Chunk object when it receives an object from the provided Observable created with the chunkClosingSelector Func1.
ChunkedOperation.ObservableBasedMultiChunkCreator(ChunkedOperation.OverlappingChunks<T, C>, Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Constructor for class rx.operators.ChunkedOperation.ObservableBasedMultiChunkCreator
 
ChunkedOperation.ObservableBasedSingleChunkCreator<T,C,TClosing> - Class in rx.operators
This ChunkedOperation.ChunkCreator creates a new ChunkedOperation.Chunk whenever it receives an object from the provided Observable created with the chunkClosingSelector Func0.
ChunkedOperation.ObservableBasedSingleChunkCreator(ChunkedOperation.NonOverlappingChunks<T, C>, Func0<? extends Observable<? extends TClosing>>) - Constructor for class rx.operators.ChunkedOperation.ObservableBasedSingleChunkCreator
 
ChunkedOperation.OverlappingChunks<T,C> - Class in rx.operators
This class is an extension on the ChunkedOperation.Chunks class which actually has no additional behavior than its super class.
ChunkedOperation.OverlappingChunks(Observer<? super C>, Func0<? extends ChunkedOperation.Chunk<T, C>>) - Constructor for class rx.operators.ChunkedOperation.OverlappingChunks
 
ChunkedOperation.SingleChunkCreator<T,C> - Class in rx.operators
This ChunkedOperation.ChunkCreator creates a new ChunkedOperation.Chunk when it is initialized, but provides no additional functionality.
ChunkedOperation.SingleChunkCreator(ChunkedOperation.Chunks<T, C>) - Constructor for class rx.operators.ChunkedOperation.SingleChunkCreator
 
ChunkedOperation.SizeBasedChunks<T,C> - Class in rx.operators
This class is an extension on the ChunkedOperation.Chunks class.
ChunkedOperation.SizeBasedChunks(Observer<? super C>, Func0<? extends ChunkedOperation.Chunk<T, C>>, int) - Constructor for class rx.operators.ChunkedOperation.SizeBasedChunks
 
ChunkedOperation.SkippingChunkCreator<T,C> - Class in rx.operators
This ChunkedOperation.ChunkCreator creates a new ChunkedOperation.Chunk every time after it has seen a certain amount of elements.
ChunkedOperation.SkippingChunkCreator(ChunkedOperation.Chunks<T, C>, int) - Constructor for class rx.operators.ChunkedOperation.SkippingChunkCreator
 
ChunkedOperation.TimeAndSizeBasedChunks<T,C> - Class in rx.operators
This class is an extension on the ChunkedOperation.Chunks class.
ChunkedOperation.TimeAndSizeBasedChunks(Observer<? super C>, Func0<? extends ChunkedOperation.Chunk<T, C>>, int, long, TimeUnit, Scheduler) - Constructor for class rx.operators.ChunkedOperation.TimeAndSizeBasedChunks
 
ChunkedOperation.TimeBasedChunkCreator<T,C> - Class in rx.operators
This ChunkedOperation.ChunkCreator creates a new ChunkedOperation.Chunk every time after a fixed period of time has elapsed.
ChunkedOperation.TimeBasedChunkCreator(ChunkedOperation.NonOverlappingChunks<T, C>, long, TimeUnit, Scheduler) - Constructor for class rx.operators.ChunkedOperation.TimeBasedChunkCreator
 
ChunkedOperation.TimeBasedChunkCreator(ChunkedOperation.OverlappingChunks<T, C>, long, TimeUnit, Scheduler) - Constructor for class rx.operators.ChunkedOperation.TimeBasedChunkCreator
 
ChunkedOperation.TimeBasedChunks<T,C> - Class in rx.operators
This class is an extension on the ChunkedOperation.Chunks class.
ChunkedOperation.TimeBasedChunks(Observer<? super C>, Func0<? extends ChunkedOperation.Chunk<T, C>>, long, TimeUnit, Scheduler) - Constructor for class rx.operators.ChunkedOperation.TimeBasedChunks
 
clear() - Method in class rx.operators.OperationReplay.VirtualArrayList
 
clear() - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
clear() - Method in interface rx.operators.OperationReplay.VirtualList
Clear the elements of this list and increase the start by the number of elements.
clear() - Method in class rx.subscriptions.CompositeSubscription
 
collect(R, Action2<R, ? super T>) - Method in class rx.Observable
Collect values into a single mutable data 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(Observable<? extends T0>, Observable<T1>, Func2<? super T0, ? super T1, ? extends R>) - Static method in class rx.operators.OperationCombineLatest
Combines the two given observables, emitting an event containing an aggregation of the latest values of each of the source observables each time an event is received from one of the source observables, where the aggregation is defined by the given function.
combineLatest(Observable<? extends T0>, Observable<? extends T1>, Observable<? extends T2>, Func3<? super T0, ? super T1, ? super T2, ? extends R>) - Static method in class rx.operators.OperationCombineLatest
 
combineLatest(Observable<? extends T0>, Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Func4<? super T0, ? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.operators.OperationCombineLatest
 
combineLatest(Observable<? extends T0>, Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Func5<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.operators.OperationCombineLatest
 
combineLatest(Observable<? extends T0>, Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Func6<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.operators.OperationCombineLatest
 
combineLatest(Observable<? extends T0>, Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Func7<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.operators.OperationCombineLatest
 
combineLatest(Observable<? extends T0>, Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Func8<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.operators.OperationCombineLatest
 
combineLatest(Observable<? extends T0>, Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, 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.operators.OperationCombineLatest
 
completed() - Method in class rx.operators.NotificationLite
Creates a lite onComplete notification without doing any allocation.
CompositeException - Exception in rx.exceptions
Exception that is a composite of 1 or more other exceptions.
CompositeException(String, Collection<Throwable>) - Constructor for exception rx.exceptions.CompositeException
 
CompositeException(Collection<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
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 an Observable, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by two Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by three Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by four Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by five Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by six Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by seven Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by eight Observables, one after the other, without interleaving them.
concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by nine Observables, one after the other, without interleaving them.
concat(Observable<? extends T>...) - Static method in class rx.operators.OperationConcat
Combine the observable sequences from the list of Observables into one observable sequence without any transformation.
concat(Iterable<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationConcat
 
concat(Observable<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationConcat
 
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.
connect() - Method in class rx.observables.ConnectableObservable
Call a ConnectableObservable's connect() method to instruct it to begin emitting the items from its underlying Observable to its Subscribers.
ConnectableObservable<T> - Class in rx.observables
A ConnectableObservable resembles an ordinary Observable, except that it does not begin emitting items when it is subscribed to, but only when its ConnectableObservable.connect() method is called.
ConnectableObservable(Observable.OnSubscribe<T>) - Constructor for class rx.observables.ConnectableObservable
 
contains(T) - Method in class rx.Observable
Returns an Observable that emits a Boolean that indicates whether the source Observable emitted a specified item.
contents - Variable in class rx.operators.ChunkedOperation.Chunk
 
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(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(Observable.OnSubscribeFunc<T>) - Static method in class rx.Observable
Deprecated. use Observable.create(OnSubscribe)
create(Action1<? super T>) - Static method in class rx.observers.Observers
Create an Observer that receives `onNext` and ignores `onError` and `onCompleted`.
create(Action1<? super T>, Action1<Throwable>) - Static method in class rx.observers.Observers
Create an Observer that receives `onNext` and `onError` and ignores `onCompleted`.
create(Action1<? super T>, Action1<Throwable>, Action0) - Static method in class rx.observers.Observers
Create an Observer that receives `onNext`, `onError` and `onCompleted`.
create(Action1<? super T>) - Static method in class rx.observers.Subscribers
Create an Subscriber that receives `onNext` and ignores `onError` and `onCompleted`.
create(Action1<? super T>, Action1<Throwable>) - Static method in class rx.observers.Subscribers
Create an Subscriber that receives `onNext` and `onError` and ignores `onCompleted`.
create(Action1<? super T>, Action1<Throwable>, Action0) - Static method in class rx.observers.Subscribers
Create an Subscriber that receives `onNext`, `onError` and `onCompleted`.
create() - Static method in class rx.operators.BufferUntilSubscriber
 
create() - Static method in class rx.operators.OperationReplay.CustomReplaySubject
Return a subject that retains all events and will replay them to an Observer that subscribes.
create(int) - Static method in class rx.operators.OperationReplay.CustomReplaySubject
Create a bounded replay subject with the given maximum buffer size.
create() - Static method in class rx.subjects.AsyncSubject
 
create(T) - Static method in class rx.subjects.BehaviorSubject
Creates a BehaviorSubject which publishes the last and all subsequent events to each Observer that subscribes to it.
create() - Static method in class rx.subjects.PublishSubject
 
create() - Static method in class rx.subjects.ReplaySubject
 
create(int) - Static method in class rx.subjects.ReplaySubject
 
create(TestScheduler) - Static method in class rx.subjects.TestSubject
 
create() - Static method in class rx.subscriptions.BooleanSubscription
 
create(Action0) - Static method in class rx.subscriptions.BooleanSubscription
 
create(Action0) - Static method in class rx.subscriptions.Subscriptions
A Subscription which invokes the given Action0 when unsubscribed.
createChunk() - Method in class rx.operators.ChunkedOperation.Chunks
This method will instantiate a new ChunkedOperation.Chunk object and register it internally.
createChunk() - Method in class rx.operators.ChunkedOperation.TimeAndSizeBasedChunks
 
createChunk() - Method in class rx.operators.ChunkedOperation.TimeBasedChunks
 
createInnerScheduler() - Method in class rx.schedulers.TestScheduler
 
createObserver(Map<Object, JoinObserver>, Observable<T>, Action1<Throwable>) - Static method in class rx.joins.Plan0
 
createOnCompleted() - Static method in class rx.Notification
 
createOnCompleted(Class<T>) - Static method in class rx.Notification
 
createOnError(Throwable) - Static method in class rx.Notification
 
createOnNext(T) - Static method in class rx.Notification
 
createScheduledSubject(Subject<T, T>, Scheduler) - Static method in class rx.operators.OperationReplay
Creates a subject whose client observers will observe events propagated through the given wrapped subject.
createWithDefaultValue(T) - Static method in class rx.subjects.BehaviorSubject
Deprecated. use #create(T) instead
currentThread() - Static method in class rx.schedulers.Schedulers
Deprecated. use Schedulers.trampoline() instead

D

debounce(Func1<? super T, ? extends Observable<U>>) - Method in class rx.Observable
Return 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
Return 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
Return 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.
debounce(Observable<T>, long, TimeUnit) - Static method in class rx.operators.OperationDebounce
This operation filters out events which are published too quickly in succession.
debounce(Observable<T>, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationDebounce
This operation filters out events which are published too quickly in succession.
debounceSelector(Observable<? extends T>, Func1<? super T, ? extends Observable<U>>) - Static method in class rx.operators.OperationDebounce
Delay the emission via another observable if no new source appears in the meantime.
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.
defaultIfEmpty(Observable<? extends T>, T) - Static method in class rx.operators.OperationDefaultIfEmpty
Returns the elements of the specified sequence or the specified default value in a singleton sequence if the sequence is empty.
defer(Func0<? extends Observable<? extends T>>) - Static method in class rx.Observable
Returns an Observable that calls an Observable factory to create its Observable for each new Observer that subscribes.
defer(Func0<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationDefer
 
degreeOfParallelism() - Method in class rx.Scheduler
Parallelism available to a Scheduler.
delay(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>) - Method in class rx.Observable
Returns an Observable that delays the subscription to and emissions from the 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.
delay(Observable<T>, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationDelay
 
delay(Observable<? extends T>, Func1<? super T, ? extends Observable<U>>) - Static method in class rx.operators.OperationDelay
Delay the emission of the source items by a per-item observable that fires its first element.
delay(Observable<? extends T>, Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>) - Static method in class rx.operators.OperationDelay
Delay the subscription and emission of the source items by a per-item observable that fires its first element.
delaySubscription(long, TimeUnit) - Method in class rx.Observable
Return 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
Return an Observable that delays the subscription to the source Observable by a given amount of time, both waiting and subscribing on a given Scheduler.
delaySubscription(Observable<? extends T>, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationDelay
Delays the subscription to the source by the given amount, running on the 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.
dematerialize(Observable<? extends Notification<? extends T>>) - Static method in class rx.operators.OperationDematerialize
Dematerializes the explicit notification values of an observable sequence as implicit notifications.
dequeue() - Method in class rx.joins.ActivePlan0
 
dequeue() - Method in interface rx.joins.JoinObserver
 
dequeue() - Method in class rx.joins.JoinObserver1
 
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.
distinct(Observable<? extends T>, Func1<? super T, ? extends U>) - Static method in class rx.operators.OperationDistinct
Returns an Observable that emits all distinct items emitted by the source
distinct(Observable<? extends T>, Comparator<T>) - Static method in class rx.operators.OperationDistinct
Returns an Observable that emits all distinct items emitted by the source
distinct(Observable<? extends T>, Func1<? super T, ? extends U>, Comparator<U>) - Static method in class rx.operators.OperationDistinct
Returns an Observable that emits all distinct items emitted by the source
distinct(Observable<? extends T>) - Static method in class rx.operators.OperationDistinct
Returns an Observable that emits all distinct items emitted by the source
distinctUntilChanged() - Method in class rx.Observable
Returns an Observable that emits all items emitted by the source Observable that are distinct from their immediate predecessors.
distinctUntilChanged(Func1<? super T, ? extends U>) - Method in class rx.Observable
Returns an Observable that emits all items emitted by the source Observable that are distinct from their immediate predecessors, according to a key selector function.
distinctUntilChanged(Observable<? extends T>, Comparator<T>) - Static method in class rx.operators.OperationDistinctUntilChanged
Returns an Observable that emits all sequentially distinct items emitted by the source.
distinctUntilChanged(Observable<? extends T>, Func1<? super T, ? extends U>, Comparator<U>) - Static method in class rx.operators.OperationDistinctUntilChanged
Returns an Observable that emits all sequentially distinct items emitted by the source.
distinctUntilChanged(Observable<? extends T>, Func1<? super T, ? extends U>) - Static method in class rx.operators.OperationDistinctUntilChanged
Returns an Observable that emits all sequentially distinct items emitted by the source.
distinctUntilChanged(Observable<? extends T>) - Static method in class rx.operators.OperationDistinctUntilChanged
Returns an Observable that emits all sequentially distinct items emitted by the source.
doOnCompleted(Action0) - Method in class rx.Observable
Modifies an Observable so that it invokes an action when it calls onCompleted.
doOnEach(Action1<Notification<? super T>>) - Method in class rx.Observable
Modifies an Observable so that it invokes an action for each item it emits.
doOnEach(Observer<? super T>) - Method in class rx.Observable
Modifies an Observable so that it notifies an Observer for each item it emits.
doOnError(Action1<Throwable>) - Method in class rx.Observable
Modifies an Observable so that it invokes an action if it calls onError.
doOnNext(Action1<? super T>) - Method in class rx.Observable
Modifies an Observable so that it invokes an action when it calls onNext.
doOnTerminate(Action0) - Method in class rx.Observable
Modifies an Observable so that it invokes an action when it calls onCompleted or onError.
drainQueue(ArrayList<Object>) - Method in class rx.observers.SerializedObserver
 

E

elementAt(int) - Method in class rx.Observable
Returns an Observable that emits the single item at a specified index in a sequence of emissions from a source Observbable.
elementAtOrDefault(int, T) - Method in class rx.Observable
Returns an Observable that emits the item found at a specified index in a sequence of emissions from a source Observable, or a default item if that index is out of range.
emitAllChunks() - Method in class rx.operators.ChunkedOperation.Chunks
This method emits all not yet emitted ChunkedOperation.Chunk objects.
emitAndReplaceChunk() - Method in class rx.operators.ChunkedOperation.NonOverlappingChunks
 
emitChunk(ChunkedOperation.Chunk<T, C>) - Method in class rx.operators.ChunkedOperation.Chunks
This method emits the specified ChunkedOperation.Chunk object.
emitChunk(ChunkedOperation.Chunk<T, C>) - Method in class rx.operators.ChunkedOperation.TimeAndSizeBasedChunks
 
emitChunk(ChunkedOperation.Chunk<T, C>) - Method in class rx.operators.ChunkedOperation.TimeBasedChunks
 
emitValueToObserver(Notification<T>, Observer<? super T>) - Static method in class rx.subjects.AsyncSubject
 
empty() - Static method in class rx.functions.Actions
 
empty() - Static method in class rx.Observable
Returns an Observable that emits no items to the Observer and immediately invokes its onCompleted method.
empty(Scheduler) - Static method in class rx.Observable
Returns an Observable that emits no items to the Observer and immediately invokes its onCompleted method on the specified Scheduler.
empty() - Static method in class rx.observers.Observers
 
empty() - Static method in class rx.observers.Subscribers
 
empty() - Static method in class rx.subscriptions.Subscriptions
A Subscription that does nothing.
empty() - Static method in class rx.util.functions.Actions
Deprecated.  
EmptyObserver<T> - Class in rx.observers
Observer that does nothing...
EmptyObserver() - Constructor for class rx.observers.EmptyObserver
 
end() - Method in class rx.operators.OperationReplay.VirtualArrayList
 
end() - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
end() - Method in interface rx.operators.OperationReplay.VirtualList
Returns the current tail index of this list (where the next value would appear).
equals(Object) - Method in class rx.Notification
 
equals(Object) - Method in class rx.schedulers.TimeInterval
 
equals(Object) - Method in class rx.schedulers.Timestamped
 
error(Throwable) - Static method in class rx.Observable
Returns an Observable that invokes an Observer's onError method when the Observer subscribes to it.
error(Throwable, Scheduler) - Static method in class rx.Observable
Returns an Observable that invokes an Observer's onError method on the specified Scheduler.
error(Throwable) - Method in class rx.operators.NotificationLite
Create a lite onError notification.
Exceptions - Class in rx.exceptions
 
executor(Executor) - Static method in class rx.schedulers.Schedulers
Scheduler that queues work on an Executor.
executor(ScheduledExecutorService) - Static method in class rx.schedulers.Schedulers
Scheduler that queues work on an ScheduledExecutorService.
ExecutorScheduler - Class in rx.schedulers
A Scheduler implementation that uses an Executor or ScheduledExecutorService implementation.
ExecutorScheduler(Executor) - Constructor for class rx.schedulers.ExecutorScheduler
Deprecated. Use Schedulers.executor();
ExecutorScheduler(ScheduledExecutorService) - Constructor for class rx.schedulers.ExecutorScheduler
Deprecated. Use Schedulers.executor();
exists(Func1<? super T, Boolean>) - Method in class rx.Observable
Returns an Observable that emits true if any item emitted by the source Observable satisfies a specified condition, otherwise false.
exists(Observable<? extends T>, Func1<? super T, Boolean>) - Static method in class rx.operators.OperationAny
 
expression - Variable in class rx.joins.Plan1
 
expression() - Method in class rx.joins.Plan1
 
expression - Variable in class rx.joins.Plan2
 
expression - Variable in class rx.joins.Plan3
 

F

filter(Func1<? super T, Boolean>) - Method in class rx.Observable
Filter items emitted by an Observable.
finallyDo(Action0) - Method in class rx.Observable
Registers an Action0 to be called when this Observable invokes either onCompleted or onError.
finallyDo(Observable<? extends T>, Action0) - Static method in class rx.operators.OperationFinally
Call a given action when a sequence completes (with or without an exception).
first() - Method in class rx.joins.Pattern1
 
first() - Method in class rx.joins.Pattern2
 
first() - Method in class rx.joins.Pattern3
 
first() - Method in class rx.Observable
Returns an Observable that emits only the very first item emitted by the source Observable, or raises an IllegalArgumentException 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 raises an IllegalArgumentException if no such items are emitted.
first() - Method in class rx.observables.BlockingObservable
Returns the first item emitted by a specified Observable, or IllegalArgumentException if source contains no elements.
first(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the first item emitted by a specified Observable that matches a predicate, or IllegalArgumentException if no such item is emitted.
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 a specified Observable, or a default value if no items are emitted.
firstOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the first item emitted by a specified Observable that matches a predicate, or a default value if no such items are emitted.
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(Observable<? extends T>, Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>) - Static method in class rx.operators.OperationFlatMap
Observable that pairs up the source values and all the derived collection values and projects them via the selector.
flatMap(Observable<? extends T>, Func1<? super T, ? extends Observable<? extends R>>, Func1<? super Throwable, ? extends Observable<? extends R>>, Func0<? extends Observable<? extends R>>) - Static method in class rx.operators.OperationFlatMap
Projects the notification of an observable sequence to an observable sequence and merges the results into one.
flatMapIterableFunc(Func1<? super T, ? extends Iterable<? extends U>>) - Static method in class rx.operators.OperationFlatMap
Converts the result Iterable of a function into an Observable.
forEach(Action1<? super T>) - Method in class rx.observables.BlockingObservable
Invoke a method on each item emitted by the Observable; block 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(Iterable<? extends T>, Scheduler) - Static method in class rx.Observable
Converts an Iterable sequence into an Observable that operates on the specified Scheduler, emitting each item from the sequence.
from(T) - Static method in class rx.Observable
Converts an item into an Observable that emits that item.
from(T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2))
from(T, T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2,t3)).
from(T, T, T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2,t3,t4)).
from(T, T, T, T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2,t3,t4,t5)).
from(T, T, T, T, T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2,t3,t4,t5,t6)).
from(T, T, T, T, T, T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2,t3,t4,t5,t6,t7)).
from(T, T, T, T, T, T, T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2,t3,t4,t5,t6,t7,t8)).
from(T, T, T, T, T, T, T, T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2,t3,t4,t5,t6,t7,t8,t9)).
from(T, T, T, T, T, T, T, T, T, T) - Static method in class rx.Observable
Deprecated. use Observable.from(Iterable) instead such as from(Arrays.asList(t1,t2,t3,t4,t5,t6,t7,t8,t9,t10)).
from(T...) - Static method in class rx.Observable
Converts an Array into an Observable that emits the items in the Array.
from(T[], Scheduler) - Static method in class rx.Observable
Converts an Array into an Observable that emits the items in the Array on a specified Scheduler.
from(Observable<? extends T>) - Static method in class rx.observables.BlockingObservable
Convert an Observable into a BlockingObservable.
from(K, Observable<T>) - Static method in class rx.observables.GroupedObservable
 
from(Observer<? super T>) - Static method in class rx.observers.Subscribers
 
from(Future<?>) - Static method in class rx.subscriptions.Subscriptions
A Subscription that wraps a Future and cancels it when unsubscribed.
from(Subscription...) - Static method in class rx.subscriptions.Subscriptions
A Subscription that groups multiple Subscriptions together and unsubscribes from all of them together.
fromAction(Action0) - Static method in class rx.functions.Functions
Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action1<? super T0>) - Static method in class rx.functions.Functions
Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action2<? super T0, ? super T1>) - Static method in class rx.functions.Functions
Convert a function to 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
Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action0) - Static method in class rx.util.functions.Functions
Deprecated. Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action1<? super T0>) - Static method in class rx.util.functions.Functions
Deprecated. Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action2<? super T0, ? super T1>) - Static method in class rx.util.functions.Functions
Deprecated. Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromAction(Action3<? super T0, ? super T1, ? super T2>) - Static method in class rx.util.functions.Functions
Deprecated. Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func0<? extends R>) - Static method in class rx.functions.Functions
Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func1<? super T0, ? extends R>) - Static method in class rx.functions.Functions
Convert a function to 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
Convert a function to 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
Convert a function to 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
Convert a function to 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
Convert a function to 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
Convert a function to 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
Convert a function to 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
Convert a function to 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
Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func0<? extends R>) - Static method in class rx.util.functions.Functions
Deprecated. Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func1<? super T0, ? extends R>) - Static method in class rx.util.functions.Functions
Deprecated. Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
fromFunc(Func2<? super T0, ? super T1, ? extends R>) - Static method in class rx.util.functions.Functions
Deprecated. Convert a function to 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.util.functions.Functions
Deprecated. Convert a function to 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.util.functions.Functions
Deprecated. Convert a function to 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.util.functions.Functions
Deprecated. Convert a function to 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.util.functions.Functions
Deprecated. Convert a function to 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.util.functions.Functions
Deprecated. Convert a function to 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.util.functions.Functions
Deprecated. Convert a function to 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.util.functions.Functions
Deprecated. Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
Func0<R> - Interface in rx.functions
 
Func0<R> - Interface in rx.util.functions
Deprecated.  
Func1<T1,R> - Interface in rx.functions
 
Func1<T1,R> - Interface in rx.util.functions
Deprecated.  
Func2<T1,T2,R> - Interface in rx.functions
 
Func2<T1,T2,R> - Interface in rx.util.functions
Deprecated.  
Func3<T1,T2,T3,R> - Interface in rx.functions
 
Func3<T1,T2,T3,R> - Interface in rx.util.functions
Deprecated.  
Func4<T1,T2,T3,T4,R> - Interface in rx.functions
 
Func4<T1,T2,T3,T4,R> - Interface in rx.util.functions
Deprecated.  
Func5<T1,T2,T3,T4,T5,R> - Interface in rx.functions
 
Func5<T1,T2,T3,T4,T5,R> - Interface in rx.util.functions
Deprecated.  
Func6<T1,T2,T3,T4,T5,T6,R> - Interface in rx.functions
 
Func6<T1,T2,T3,T4,T5,T6,R> - Interface in rx.util.functions
Deprecated.  
Func7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in rx.functions
 
Func7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in rx.util.functions
Deprecated.  
Func8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in rx.functions
 
Func8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in rx.util.functions
Deprecated.  
Func9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in rx.functions
 
Func9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in rx.util.functions
Deprecated.  
FuncN<R> - Interface in rx.functions
 
FuncN<R> - Interface in rx.util.functions
Deprecated.  
Function - Interface in rx.functions
All Func and Action interfaces extend from this.
Function - Interface in rx.util.functions
Deprecated.  
Functions - Class in rx.functions
 
Functions() - Constructor for class rx.functions.Functions
 
Functions - Class in rx.util.functions
Deprecated.  
Functions() - Constructor for class rx.util.functions.Functions
Deprecated.  

G

get(int) - Method in class rx.operators.OperationReplay.VirtualArrayList
 
get(int) - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
get(int) - Method in interface rx.operators.OperationReplay.VirtualList
Retrieve an element at the specified logical index.
get() - Method in class rx.subscriptions.MultipleAssignmentSubscription
 
get() - Method in class rx.subscriptions.RefCountSubscription
Returns a new sub-subscription.
get() - Method in class rx.subscriptions.SerialSubscription
 
getActual() - Method in class rx.observers.SafeSubscriber
 
getCause() - Method in exception rx.exceptions.CompositeException
 
getChunk() - Method in class rx.operators.ChunkedOperation.Chunks
 
getComputationScheduler() - Method in class rx.plugins.RxJavaDefaultSchedulers
Scheduler to return from Schedulers.computation() or null if default should be used.
getContents() - Method in class rx.operators.ChunkedOperation.Chunk
 
getContents() - Method in class rx.operators.OperationBuffer.Buffer
 
getContents() - Method in class rx.operators.OperationWindow.Window
 
getDefaultSchedulers() - Method in class rx.plugins.RxJavaPlugins
Retrieve instance of RxJavaDefaultSchedulers to use based on order of precedence as defined in RxJavaPlugins class header.
getError(Object) - Method in class rx.operators.NotificationLite
returns Throwable passed in NotificationLite.error(Throwable) method call.
getErrorHandler() - Method in class rx.plugins.RxJavaPlugins
Retrieve instance of RxJavaErrorHandler to use based on order of precedence as defined in RxJavaPlugins class header.
getEvents() - Method in class rx.observers.TestObserver
 
getExceptions() - Method in exception rx.exceptions.CompositeException
 
getFinalCause(Throwable) - Static method in class rx.exceptions.Exceptions
 
getInstance() - Static method in class rx.plugins.RxJavaPlugins
 
getInstance() - Static method in class rx.schedulers.ImmediateScheduler
Deprecated. Use Schedulers.immediate();
getInstance() - Static method in class rx.schedulers.NewThreadScheduler
Deprecated. Use Schedulers.newThread();
getInstance() - Static method in class rx.schedulers.TrampolineScheduler
Deprecated. Use Schedulers.trampoline();
getIntervalInMilliseconds() - Method in class rx.schedulers.TimeInterval
Returns the interval in milliseconds.
getIOScheduler() - Method in class rx.plugins.RxJavaDefaultSchedulers
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 a specified Observable.
getKey() - Method in class rx.observables.GroupedObservable
Returns the key the elements in this observable were grouped by.
getKind() - Method in class rx.Notification
Retrieves the kind of the notification: OnNext, OnError, OnCompleted
getLastSeenThread() - Method in class rx.observers.TestSubscriber
 
getMessage() - Method in exception rx.exceptions.CompositeException
 
getNewThreadScheduler() - Method in class rx.plugins.RxJavaDefaultSchedulers
Scheduler to return from Schedulers.newThread() or null if default should be used.
getObservableExecutionHook() - Method in class rx.plugins.RxJavaPlugins
Retrieve instance of RxJavaObservableExecutionHook to use based on order of precedence as defined in RxJavaPlugins class header.
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
 
getOnNextEvents() - Method in class rx.observers.TestSubscriber
 
getSubscription() - Method in class rx.subscriptions.MultipleAssignmentSubscription
Deprecated. 
getSubscription() - Method in class rx.subscriptions.RefCountSubscription
Deprecated. 
getSubscription() - Method in class rx.subscriptions.SerialSubscription
Deprecated. 
getThrowable() - Method in class rx.Notification
Retrieves the exception associated with an onError notification.
getTimestampMillis() - Method in class rx.schedulers.Timestamped
Returns time timestamp, in milliseconds.
getValue() - Method in exception rx.exceptions.OnErrorThrowable
 
getValue() - Method in exception rx.exceptions.OnErrorThrowable.OnNextValue
 
getValue() - Method in class rx.Notification
Retrieves the data associated with an onNext notification.
getValue(Object) - Method in class rx.operators.NotificationLite
returns value passed in NotificationLite.next(Object) method call.
getValue() - Method in class rx.schedulers.TimeInterval
Returns the value.
getValue() - Method in class rx.schedulers.Timestamped
Returns the value.
groupBy(Func1<? super T, ? extends K>) - Method in class rx.Observable
Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as GroupedObservables, 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
An Observable that has been grouped by a key whose value can be obtained using GroupedObservable.getKey()
GroupedObservable(K, Observable.OnSubscribe<T>) - Constructor for class rx.observables.GroupedObservable
 
groupJoin(Observable<T2>, Func1<? super T, ? extends Observable<D1>>, Func1<? super T2, ? extends Observable<D2>>, Func2<? super T, ? super Observable<T2>, ? extends R>) - Method in class rx.Observable
Return an Observable that correlates two Observables when they overlap in time and groups the results.

H

handleError(Throwable) - Method in class rx.plugins.RxJavaErrorHandler
Receives all Exceptions from an Observable passed to Observer.onError(Throwable).
hashCode() - Method in class rx.Notification
 
hashCode() - Method in class rx.schedulers.TimeInterval
 
hashCode() - Method in class rx.schedulers.Timestamped
 
hasThrowable() - Method in class rx.Notification
Retrieves a value indicating whether this notification has an exception.
hasValue() - Method in class rx.Notification
Retrieves a value indicating whether this notification has a value.

I

identity() - Static method in class rx.functions.Functions
 
identity() - Static method in class rx.util.functions.Functions
Deprecated.  
ignoreElements() - Method in class rx.Observable
Ignores all items emitted by the source Observable and only calls onCompleted or onError.
immediate() - Static method in class rx.schedulers.Schedulers
Scheduler that executes work immediately on the current thread.
ImmediateScheduler - Class in rx.schedulers
Executes work immediately on the current thread.
instance() - Static method in class rx.operators.NotificationLite
 
intermediateSelector - Variable in class rx.operators.OperationReplay.CustomReplaySubject
The result selector.
interval(long, TimeUnit) - Static method in class rx.Observable
Returns an Observable that emits a sequential number every specified interval of time.
interval(long, TimeUnit, Scheduler) - Static method in class rx.Observable
Returns an Observable that emits a sequential number every specified interval of time, on a specified Scheduler.
interval(long, TimeUnit) - Static method in class rx.operators.OperationInterval
Creates an event each time interval.
interval(long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationInterval
Creates an event each time interval.
io() - Static method in class rx.schedulers.Schedulers
Scheduler intended for IO-bound work.
isCompleted(Object) - Method in class rx.operators.NotificationLite
 
isEmpty() - Method in class rx.Observable
Returns an Observable that emits true if the source Observable is empty, otherwise false.
isEmpty(Observable<? extends T>) - Static method in class rx.operators.OperationAny
 
isError(Object) - Method in class rx.operators.NotificationLite
 
isOnCompleted() - Method in class rx.Notification
 
isOnError() - Method in class rx.Notification
 
isOnNext() - Method in class rx.Notification
 
isUnsubscribed() - Method in class rx.operators.ChunkedOperation.TimeAndSizeBasedChunks
 
isUnsubscribed() - Method in class rx.operators.ChunkedOperation.TimeBasedChunks
 
isUnsubscribed() - Method in class rx.operators.SafeObservableSubscription
Deprecated.  
isUnsubscribed() - Method in class rx.Subscriber
 
isUnsubscribed() - Method in interface rx.Subscription
 
isUnsubscribed() - Method in class rx.subscriptions.BooleanSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.CompositeSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.MultipleAssignmentSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.RefCountSubscription
Check if this subscription is already unsubscribed.
isUnsubscribed() - Method in class rx.subscriptions.SerialSubscription
 
isValueNull() - Method in exception rx.exceptions.OnErrorThrowable
 

J

join(Observable<TRight>, Func1<T, Observable<TLeftDuration>>, Func1<TRight, Observable<TRightDuration>>, Func2<T, TRight, R>) - Method in class rx.Observable
Correlates the items emitted by two Observables based on overlapping durations.
JoinObserver - Interface in rx.joins
Base interface to manage joined observations.
JoinObserver1<T> - Class in rx.joins
Default implementation of a join observer.
JoinObserver1(Observable<T>, Action1<Throwable>) - Constructor for class rx.joins.JoinObserver1
 
joinObservers - Variable in class rx.joins.ActivePlan0
 
just(T) - Static method in class rx.Observable
Returns an Observable that emits a single item and then completes.
just(T, Scheduler) - Static method in class rx.Observable
Deprecated. use #from(T)

K

kind(Object) - Method in class rx.operators.NotificationLite
If there is custom logic that isn't as simple as call the right method on an Observer then this method can be used to get the Notification.Kind

L

last() - Method in class rx.Observable
Returns an Observable that emits the last item emitted by the source Observable or notifies observers of an IllegalArgumentException 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 an IllegalArgumentException if no such items are emitted.
last() - Method in class rx.observables.BlockingObservable
Returns the last item emitted by a specified Observable, or throws IllegalArgumentException if it emits no items.
last(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the last item emitted by a specified Observable that matches a predicate, or throws IllegalArgumentException 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 a specified Observable, or a default value if no items are emitted.
lastOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the last item emitted by a specified Observable that matches a predicate, or a default value if no such items are emitted.
latest() - Method in class rx.observables.BlockingObservable
Returns the latest item emitted by the underlying Observable, waiting if necessary for one to become available.
latest(Observable<? extends T>) - Static method in class rx.operators.OperationLatest
 
left - Variable in class rx.operators.OperationGroupJoin
 
leftDuration - Variable in class rx.operators.OperationGroupJoin
 
lift(Observable.Operator<? extends R, ? super T>) - Method in class rx.Observable
Lift a function to the current Observable and return a new Observable that when subscribed to will pass the values of the current Observable through the function.
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.

M

map(Func1<? super T, ? extends R>) - Method in class rx.Observable
Returns an Observable that applies a specified function to each item emitted by the source Observable and emits the results of these function applications.
mapMany(Func1<? super T, ? extends Observable<R>>) - Method in class rx.Observable
Deprecated. use Observable.flatMap(Func1)
match() - Method in class rx.joins.ActivePlan0
 
match() - Method in class rx.joins.ActivePlan1
 
match() - Method in class rx.joins.ActivePlan2
 
match() - Method in class rx.joins.ActivePlan3
 
materialize() - Method in class rx.Observable
Turns all of the emissions and notifications from a source Observable into emissions marked with their original types within Notification objects.
materialize(Observable<? extends T>) - Static method in class rx.operators.OperationMaterialize
Materializes the implicit notifications of an observable sequence as explicit notification values.
max(Observable<T>) - Static method in class rx.Observable
Deprecated. use rxjava-math module instead
max(Comparator<? super T>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
max(Observable<T>) - Static method in class rx.operators.OperationMinMax
 
max(Observable<T>, Comparator<? super T>) - Static method in class rx.operators.OperationMinMax
 
maxBy(Func1<T, R>) - Method in class rx.Observable
Returns an Observable that emits a List of items emitted by the source Observable that have the maximum key value.
maxBy(Func1<T, R>, Comparator<? super R>) - Method in class rx.Observable
Returns an Observable that emits a List of items emitted by the source Observable that have the maximum key value according to a specified comparator.
maxBy(Observable<T>, Func1<T, R>) - Static method in class rx.operators.OperationMinMax
 
maxBy(Observable<T>, Func1<T, R>, Comparator<? super R>) - Static method in class rx.operators.OperationMinMax
 
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(Iterable<? extends Observable<? extends T>>, int, Scheduler) - 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, and subscribing to these Observables on a specified Scheduler.
merge(Iterable<? extends Observable<? extends T>>, Scheduler) - Static method in class rx.Observable
Flattens an Iterable of Observables into one Observable, without any transformation, subscribing to these Observables on a specified Scheduler.
merge(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Flattens an Observable that emits Observables into a single Observable that emits the items emitted by those Observables, without any transformation.
merge(Observable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
Flattens an Observable that emits Observables into a single Observable that emits the items emitted by those Observables, without any transformation, while limiting the maximum number of concurrent subscriptions to these Observables.
merge(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens two Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens three Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens four Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens five Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens six Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens seven Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens eight Observables into a single Observable, without any transformation.
merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Flattens nine Observables into a single Observable, without any transformation.
merge(Observable<? extends T>[]) - Static method in class rx.Observable
Flattens an Array of Observables into one Observable, without any transformation.
merge(Observable<? extends T>[], Scheduler) - Static method in class rx.Observable
Flattens an Array of Observables into one Observable, without any transformation, traversing the array on a specified Scheduler.
merge(Observable<? extends Observable<? extends T>>, int) - Static method in class rx.operators.OperationMergeMaxConcurrent
 
mergeDelayError(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
A version of merge 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
A version of merge 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>) - Static method in class rx.Observable
A version of merge 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
A version of merge 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
A version of merge 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
A version of merge 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
A version of merge 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
A version of merge 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
A version of merge that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
mergeDelayError(Observable<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationMergeDelayError
Flattens the observable sequences from the list of Observables into one observable sequence without any transformation and delays any onError calls until after all sequences have called onError or onComplete so as to allow all successful onNext calls to be received.
mergeDelayError(Observable<? extends T>...) - Static method in class rx.operators.OperationMergeDelayError
 
mergeDelayError(List<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationMergeDelayError
 
mergeMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Returns an Observable that emits the results of applying a specified function 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.
mergeMap(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.
mergeMap(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.
mergeMapIterable(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.
mergeMapIterable(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.
min(Observable<T>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
min(Comparator<? super T>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
min(Observable<T>) - Static method in class rx.operators.OperationMinMax
 
min(Observable<T>, Comparator<? super T>) - Static method in class rx.operators.OperationMinMax
 
minBy(Func1<T, R>) - Method in class rx.Observable
Returns an Observable that emits a List of items emitted by the source Observable that have the minimum key value.
minBy(Func1<T, R>, Comparator<? super R>) - Method in class rx.Observable
Returns an Observable that emits a List of items emitted by the source Observable that have the minimum key value according to a given comparator function.
minBy(Observable<T>, Func1<T, R>) - Static method in class rx.operators.OperationMinMax
 
minBy(Observable<T>, Func1<T, R>, Comparator<? super R>) - Static method in class rx.operators.OperationMinMax
 
mostRecent(T) - Method in class rx.observables.BlockingObservable
Returns an Iterable that always returns the item most recently emitted by an Observable.
mostRecent(Observable<? extends T>, T) - Static method in class rx.operators.OperationMostRecent
 
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(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.
multicast(Observable<? extends T>, Subject<? super T, ? extends R>) - Static method in class rx.operators.OperationMulticast
 
multicast(Observable<? extends TInput>, Func0<? extends Subject<? super TInput, ? extends TIntermediate>>, Func1<? super Observable<TIntermediate>, ? extends Observable<TResult>>) - Static method in class rx.operators.OperationMulticast
Returns an observable sequence that contains the elements of a sequence produced by multicasting the source sequence within a selector function.
MultipleAssignmentSubscription - Class in rx.subscriptions
Subscription that can be checked for status such as in a loop inside an Observable to exit the loop if unsubscribed.
MultipleAssignmentSubscription() - Constructor for class rx.subscriptions.MultipleAssignmentSubscription
 

N

nest() - Method in class rx.Observable
Convert the current Observable<T> into an Observable<Observable<T>>.
never() - Static method in class rx.Observable
Returns an Observable that never sends any items or notifications to an Observer.
newThread() - Static method in class rx.schedulers.Schedulers
Scheduler that creates a new Thread for each unit of work.
NewThreadScheduler - Class in rx.schedulers
Schedules work on a new thread.
next() - Method in class rx.observables.BlockingObservable
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
next(T) - Method in class rx.operators.NotificationLite
Creates a lite onNext notification for the value passed in without doing any allocation.
next(Observable<? extends T>) - Static method in class rx.operators.OperationNext
 
not(Func1<? super T, Boolean>) - Static method in class rx.functions.Functions
Constructs a predicate that returns true for each input that the source predicate returns false for and vice versa.
Not<T> - Class in rx.functions
Implements the negation of a predicate.
Not(Func1<? super T, Boolean>) - Constructor for class rx.functions.Not
Constructs a predicate that returns true for each input that the source predicate returns false for and vice versa.
not(Func1<? super T, Boolean>) - Static method in class rx.util.functions.Functions
Deprecated. Constructs a predicate that returns true for each input that the source predicate returns false for and vice versa.
Not<T> - Class in rx.util.functions
Deprecated.  
Not(Func1<? super T, Boolean>) - Constructor for class rx.util.functions.Not
Deprecated. Constructs a predicate that returns true for each input that the source predicate returns false for and vice versa.
Notification<T> - Class in rx
An object representing a notification sent to an Observable.
Notification(T) - Constructor for class rx.Notification
Deprecated. 
Notification(Throwable) - Constructor for class rx.Notification
Deprecated. Because type Throwable can't disambiguate the constructors if both onNext and onError are type "Throwable"
Notification() - Constructor for class rx.Notification
Deprecated. 
Notification.Kind - Enum in rx
 
NotificationLite<T> - Class in rx.operators
For use in internal operators that need something like materialize and dematerialize wholly within the implementation of the operator but don't want to incur the allocation cost of actually creating Notification objects for every onNext and onComplete.
now() - Method in class rx.Scheduler.Inner
 
now() - Method in class rx.Scheduler
 
now() - Method in class rx.schedulers.TestScheduler
 

O

Observable<T> - Class in rx
The Observable class that implements the Reactive Pattern.
Observable(Observable.OnSubscribe<T>) - Constructor for class rx.Observable
Observable with Function to execute when subscribed to.
Observable.OnSubscribe<T> - Interface in rx
Invoked when Obserable.subscribe is called.
Observable.OnSubscribeFunc<T> - Interface in rx
 
Observable.Operator<R,T> - Interface in rx
Operator function for lifting into an Observable.
observeOn(Scheduler) - Method in class rx.Observable
Move notifications to the 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
 
Observers() - Constructor for class rx.observers.Observers
 
ofType(Class<R>) - Method in class rx.Observable
Filters the items emitted by an Observable, only emitting those of the specified type.
onCompleted() - Method in class rx.joins.JoinObserver1
 
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.SynchronizedObserver
Deprecated.  
onCompleted() - Method in class rx.observers.SynchronizedSubscriber
Deprecated.  
onCompleted() - Method in class rx.observers.TestObserver
 
onCompleted() - Method in class rx.observers.TestSubscriber
 
onCompleted() - Method in class rx.operators.BufferUntilSubscriber
 
onCompleted() - Method in class rx.operators.ChunkedOperation.ChunkObserver
 
onCompleted() - Method in class rx.operators.OperationGroupByUntil.GroupSubject
 
onCompleted() - Method in class rx.operators.OperationReplay.CustomReplaySubject
 
onCompleted() - Method in class rx.operators.OperationReplay.SubjectWrapper
 
onCompleted() - Method in class rx.operators.OperationToMap.ToMap.ToMapObserver
 
onCompleted() - Method in class rx.operators.OperationToMultimap.ToMultimap.ToMultimapObserver
 
onCompleted() - Method in class rx.operators.SafeObserver
Deprecated.  
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
 
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.
onCompletedFrom(Observer<T>) - Static method in class rx.util.functions.Actions
Deprecated. 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
Invoked during the construction by Observable.create(OnSubscribe)
onError(Throwable) - Method in class rx.joins.JoinObserver1
 
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.SynchronizedObserver
Deprecated.  
onError(Throwable) - Method in class rx.observers.SynchronizedSubscriber
Deprecated.  
onError(Throwable) - Method in class rx.observers.TestObserver
 
onError(Throwable) - Method in class rx.observers.TestSubscriber
 
onError(Throwable) - Method in class rx.operators.BufferUntilSubscriber
 
onError(Throwable) - Method in class rx.operators.ChunkedOperation.ChunkObserver
 
onError(Throwable) - Method in class rx.operators.OperationGroupByUntil.GroupSubject
 
onError(Throwable) - Method in class rx.operators.OperationReplay.CustomReplaySubject
 
onError(Throwable) - Method in class rx.operators.OperationReplay.SubjectWrapper
 
onError(Throwable) - Method in class rx.operators.OperationToMap.ToMap.ToMapObserver
 
onError(Throwable) - Method in class rx.operators.OperationToMultimap.ToMultimap.ToMultimapObserver
 
onError(Throwable) - Method in class rx.operators.SafeObserver
Deprecated.  
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
 
OnErrorFailedException - Exception in rx.exceptions
Used for re-throwing errors thrown from Observer.onError(Throwable).
OnErrorFailedException(String, Throwable) - Constructor for exception rx.exceptions.OnErrorFailedException
 
OnErrorFailedException(Throwable) - Constructor for exception rx.exceptions.OnErrorFailedException
 
onErrorFlatMap(Func1<OnErrorThrowable, ? extends Observable<? extends T>>) - Method in class rx.Observable
Allows inserting onNext events into a stream when onError events are received and continuing the original sequence instead of terminating.
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.
onErrorFrom(Observer<T>) - Static method in class rx.util.functions.Actions
Deprecated. Extracts a method reference to the observer's onError method in the form of an Action1.
OnErrorNotImplementedException - Exception in rx.exceptions
Used for re-throwing Observer.onError(Throwable) when an implementation doesn't exist.
OnErrorNotImplementedException(String, Throwable) - Constructor for exception rx.exceptions.OnErrorNotImplementedException
 
OnErrorNotImplementedException(Throwable) - Constructor for exception rx.exceptions.OnErrorNotImplementedException
 
onErrorResumeNext(Func1<Throwable, ? extends Observable<? extends T>>) - Method in class rx.Observable
Instruct 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
Instruct an Observable to pass control to another Observable rather than invoking onError if it encounters an error.
onErrorResumeNextViaObservable(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.operators.OperationOnErrorResumeNextViaObservable
 
onErrorReturn(Func1<Throwable, ? extends T>) - Method in class rx.Observable
Instruct an Observable to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
onErrorReturn(Observable<? extends T>, Func1<Throwable, ? extends T>) - Static method in class rx.operators.OperationOnErrorReturn
 
OnErrorThrowable - Exception in rx.exceptions
 
OnErrorThrowable.OnNextValue - Exception in rx.exceptions
 
OnErrorThrowable.OnNextValue(Object) - Constructor for exception rx.exceptions.OnErrorThrowable.OnNextValue
 
onExceptionResumeNext(Observable<? extends T>) - Method in class rx.Observable
Instruct an Observable to pass control to another Observable rather than invoking onError if it encounters an Exception.
onExceptionResumeNextViaObservable(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.operators.OperationOnExceptionResumeNextViaObservable
 
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(Notification<T>) - Method in class rx.joins.JoinObserver1
 
onNext(T) - Method in interface rx.Observer
Provides the Observer with new data.
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.SynchronizedObserver
Deprecated.  
onNext(T) - Method in class rx.observers.SynchronizedSubscriber
Deprecated.  
onNext(T) - Method in class rx.observers.TestObserver
 
onNext(T) - Method in class rx.observers.TestSubscriber
 
onNext(T) - Method in class rx.operators.BufferUntilSubscriber
 
onNext(T) - Method in class rx.operators.ChunkedOperation.ChunkObserver
 
onNext(V) - Method in class rx.operators.OperationGroupByUntil.GroupSubject
 
onNext(TInput) - Method in class rx.operators.OperationReplay.CustomReplaySubject
 
onNext(T) - Method in class rx.operators.OperationReplay.SubjectWrapper
 
onNext(T) - Method in class rx.operators.OperationToMap.ToMap.ToMapObserver
 
onNext(T) - Method in class rx.operators.OperationToMultimap.ToMultimap.ToMultimapObserver
 
onNext(T) - Method in class rx.operators.SafeObserver
Deprecated.  
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
 
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.
onNextFrom(Observer<T>) - Static method in class rx.util.functions.Actions
Deprecated. Extracts a method reference to the observer's onNext method in the form of an Action1.
onSubscribe(Observer<? super T>) - Method in interface rx.Observable.OnSubscribeFunc
 
onSubscribe(Observer<? super T>) - Method in class rx.operators.OperationAsObservable
 
onSubscribe(Observer<? super Double>) - Method in class rx.operators.OperationAverage.AverageDoubleExtractor
 
onSubscribe(Observer<? super Float>) - Method in class rx.operators.OperationAverage.AverageFloatExtractor
 
onSubscribe(Observer<? super Integer>) - Method in class rx.operators.OperationAverage.AverageIntegerExtractor
 
onSubscribe(Observer<? super Long>) - Method in class rx.operators.OperationAverage.AverageLongExtractor
 
onSubscribe(Observer<? super GroupedObservable<TKey, TResult>>) - Method in class rx.operators.OperationGroupByUntil
 
onSubscribe(Observer<? super R>) - Method in class rx.operators.OperationGroupJoin
 
onSubscribe(Observer<? super R>) - Method in class rx.operators.OperationJoin
 
onSubscribe(Observer<? super TResult>) - Method in class rx.operators.OperationReplay.CustomReplaySubjectSubscribeFunc
 
onSubscribe(Observer<? super T>) - Method in class rx.operators.OperationSample.SampleWithObservable
 
onSubscribe(Observer<? super T>) - Method in class rx.operators.OperationSkip.SkipTimed
 
onSubscribe(Observer<? super T>) - Method in class rx.operators.OperationSkipLast.SkipLastTimed
 
onSubscribe(Observer<? super T>) - Method in class rx.operators.OperationSkipUntil
 
onSubscribe(Observer<? super T>) - Method in class rx.operators.OperationTakeTimed.TakeTimed
 
onSubscribe(Observer<? super Long>) - Method in class rx.operators.OperationTimer.TimerOnce
 
onSubscribe(Observer<? super Long>) - Method in class rx.operators.OperationTimer.TimerPeriodically
 
onSubscribe(Observer<? super Map<K, V>>) - Method in class rx.operators.OperationToMap.ToMap
 
onSubscribe(Observer<? super Map<K, Collection<V>>>) - Method in class rx.operators.OperationToMultimap.ToMultimap
 
onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaObservableExecutionHook
Invoked after failed execution of Observable.subscribe(Subscriber) with thrown Throwable.
OnSubscribeFromIterable<T> - Class in rx.operators
Converts an Iterable sequence into an Observable.
OnSubscribeFromIterable(Iterable<? extends T>) - Constructor for class rx.operators.OnSubscribeFromIterable
 
OnSubscribeRange - Class in rx.operators
Emit ints from start to end inclusive.
OnSubscribeRange(int, int) - Constructor for class rx.operators.OnSubscribeRange
 
onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaObservableExecutionHook
Invoked after successful execution of Observable.subscribe(rx.Subscriber) with returned Subscription.
onSubscribeStart(Observable<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
Invoked before Observable.subscribe(rx.Subscriber) is about to be executed.
onValuePushed() - Method in interface rx.operators.ChunkedOperation.ChunkCreator
Signifies a onNext event.
onValuePushed() - Method in class rx.operators.ChunkedOperation.ObservableBasedMultiChunkCreator
 
onValuePushed() - Method in class rx.operators.ChunkedOperation.ObservableBasedSingleChunkCreator
 
onValuePushed() - Method in class rx.operators.ChunkedOperation.SingleChunkCreator
 
onValuePushed() - Method in class rx.operators.ChunkedOperation.SkippingChunkCreator
 
onValuePushed() - Method in class rx.operators.ChunkedOperation.TimeBasedChunkCreator
 
OperationAll - Class in rx.operators
Returns an Observable that emits a Boolean that indicates whether all items emitted by an Observable satisfy a condition.
OperationAll() - Constructor for class rx.operators.OperationAll
 
OperationAny - Class in rx.operators
Returns an Observable that emits true if any element of an observable sequence satisfies a condition, otherwise false.
OperationAny() - Constructor for class rx.operators.OperationAny
 
OperationAsObservable<T> - Class in rx.operators
Hides the identity of another observable.
OperationAsObservable(Observable<? extends T>) - Constructor for class rx.operators.OperationAsObservable
 
OperationAverage - Class in rx.operators
A few operators for implementing the averaging operation.
OperationAverage() - Constructor for class rx.operators.OperationAverage
 
OperationAverage.AverageDoubleExtractor<T> - Class in rx.operators
Compute the average by extracting double values from the source via an extractor function.
OperationAverage.AverageDoubleExtractor(Observable<? extends T>, Func1<? super T, Double>) - Constructor for class rx.operators.OperationAverage.AverageDoubleExtractor
 
OperationAverage.AverageFloatExtractor<T> - Class in rx.operators
Compute the average by extracting float values from the source via an extractor function.
OperationAverage.AverageFloatExtractor(Observable<? extends T>, Func1<? super T, Float>) - Constructor for class rx.operators.OperationAverage.AverageFloatExtractor
 
OperationAverage.AverageIntegerExtractor<T> - Class in rx.operators
Compute the average by extracting integer values from the source via an extractor function.
OperationAverage.AverageIntegerExtractor(Observable<? extends T>, Func1<? super T, Integer>) - Constructor for class rx.operators.OperationAverage.AverageIntegerExtractor
 
OperationAverage.AverageLongExtractor<T> - Class in rx.operators
Compute the average by extracting long values from the source via an extractor function.
OperationAverage.AverageLongExtractor(Observable<? extends T>, Func1<? super T, Long>) - Constructor for class rx.operators.OperationAverage.AverageLongExtractor
 
OperationBuffer - Class in rx.operators
 
OperationBuffer() - Constructor for class rx.operators.OperationBuffer
 
OperationBuffer.Buffer<T> - Class in rx.operators
This class represents a single buffer: A sequence of recorded values.
OperationBuffer.Buffer() - Constructor for class rx.operators.OperationBuffer.Buffer
 
OperationCache - Class in rx.operators
This method has similar behavior to Observable.replay() except that this auto-subscribes to the source Observable rather than returning a connectable Observable.
OperationCache() - Constructor for class rx.operators.OperationCache
 
OperationCombineLatest - Class in rx.operators
Returns an Observable that combines the emissions of multiple source observables.
OperationCombineLatest() - Constructor for class rx.operators.OperationCombineLatest
 
OperationConcat - Class in rx.operators
Returns an Observable that emits the items emitted by two or more Observables, one after the other.
OperationConcat() - Constructor for class rx.operators.OperationConcat
 
OperationDebounce - Class in rx.operators
This operation is used to filter out bursts of events.
OperationDebounce() - Constructor for class rx.operators.OperationDebounce
 
OperationDefaultIfEmpty - Class in rx.operators
Returns the elements of the specified sequence or the specified default value in a singleton sequence if the sequence is empty.
OperationDefaultIfEmpty() - Constructor for class rx.operators.OperationDefaultIfEmpty
 
OperationDefer - Class in rx.operators
Do not create the Observable until an Observer subscribes; create a fresh Observable on each subscription.
OperationDefer() - Constructor for class rx.operators.OperationDefer
 
OperationDelay - Class in rx.operators
 
OperationDelay() - Constructor for class rx.operators.OperationDelay
 
OperationDematerialize - Class in rx.operators
Reverses the effect of OperationMaterialize by transforming the Notification objects emitted by a source Observable into the items or notifications they represent.
OperationDematerialize() - Constructor for class rx.operators.OperationDematerialize
 
OperationDistinct - Class in rx.operators
Returns an Observable that emits all distinct items emitted by the source.
OperationDistinct() - Constructor for class rx.operators.OperationDistinct
 
OperationDistinctUntilChanged - Class in rx.operators
Returns an Observable that emits all sequentially distinct items emitted by the source.
OperationDistinctUntilChanged() - Constructor for class rx.operators.OperationDistinctUntilChanged
 
OperationFinally - Class in rx.operators
Registers an action to be called when an Observable invokes onComplete or onError.
OperationFinally() - Constructor for class rx.operators.OperationFinally
 
OperationFlatMap - Class in rx.operators
Additional flatMap operators.
OperationGroupByUntil<TSource,TKey,TResult,TDuration> - Class in rx.operators
Groups the elements of an observable sequence according to a specified key selector, value selector and duration selector function.
OperationGroupByUntil(Observable<TSource>, Func1<? super TSource, ? extends TKey>, Func1<? super TSource, ? extends TResult>, Func1<? super GroupedObservable<TKey, TResult>, ? extends Observable<? extends TDuration>>) - Constructor for class rx.operators.OperationGroupByUntil
 
OperationGroupByUntil.GroupSubject<K,V> - Class in rx.operators
A grouped observable with subject-like behavior.
OperationGroupByUntil.GroupSubject(K, Subject<V, V>) - Constructor for class rx.operators.OperationGroupByUntil.GroupSubject
 
OperationGroupJoin<T1,T2,D1,D2,R> - Class in rx.operators
Corrrelates two sequences when they overlap and groups the results.
OperationGroupJoin(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.operators.OperationGroupJoin
 
OperationInterval - Class in rx.operators
Returns an observable sequence that produces a value after each period.
OperationInterval() - Constructor for class rx.operators.OperationInterval
 
OperationJoin<TLeft,TRight,TLeftDuration,TRightDuration,R> - Class in rx.operators
Correlates the elements of two sequences based on overlapping durations.
OperationJoin(Observable<TLeft>, Observable<TRight>, Func1<TLeft, Observable<TLeftDuration>>, Func1<TRight, Observable<TRightDuration>>, Func2<TLeft, TRight, R>) - Constructor for class rx.operators.OperationJoin
 
OperationJoinPatterns - Class in rx.operators
Join patterns: And, Then, When.
OperationJoinPatterns() - Constructor for class rx.operators.OperationJoinPatterns
 
OperationLatest - Class in rx.operators
Wait for and iterate over the latest values of the source observable.
OperationMaterialize - Class in rx.operators
Turns all of the notifications from an Observable into onNext emissions, and marks them with their original notification types within Notification objects.
OperationMaterialize() - Constructor for class rx.operators.OperationMaterialize
 
OperationMergeDelayError - Class in rx.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.
OperationMergeDelayError() - Constructor for class rx.operators.OperationMergeDelayError
 
OperationMergeMaxConcurrent - Class in rx.operators
Flattens a list of Observables into one Observable sequence, without any transformation.
OperationMergeMaxConcurrent() - Constructor for class rx.operators.OperationMergeMaxConcurrent
 
OperationMinMax - Class in rx.operators
Returns the minimum element in an observable sequence.
OperationMinMax() - Constructor for class rx.operators.OperationMinMax
 
OperationMostRecent - Class in rx.operators
Returns an Iterable that always returns the item most recently emitted by an Observable, or a seed value if no item has yet been emitted.
OperationMostRecent() - Constructor for class rx.operators.OperationMostRecent
 
OperationMulticast - Class in rx.operators
 
OperationMulticast() - Constructor for class rx.operators.OperationMulticast
 
OperationNext - Class in rx.operators
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
OperationNext() - Constructor for class rx.operators.OperationNext
 
OperationOnErrorResumeNextViaObservable<T> - Class in rx.operators
Instruct an Observable to pass control to another Observable rather than invoking onError if it encounters an error.
OperationOnErrorResumeNextViaObservable() - Constructor for class rx.operators.OperationOnErrorResumeNextViaObservable
 
OperationOnErrorReturn<T> - Class in rx.operators
Instruct an Observable to emit a particular item to its Observer's onNext method rather than invoking onError if it encounters an error.
OperationOnErrorReturn() - Constructor for class rx.operators.OperationOnErrorReturn
 
OperationOnExceptionResumeNextViaObservable<T> - Class in rx.operators
Instruct an Observable to pass control to another Observable rather than invoking onError if it encounters an error of type Exception.
OperationOnExceptionResumeNextViaObservable() - Constructor for class rx.operators.OperationOnExceptionResumeNextViaObservable
 
OperationParallelMerge - Class in rx.operators
 
OperationParallelMerge() - Constructor for class rx.operators.OperationParallelMerge
 
OperationRefCount<T> - Class in rx.operators
Returns an observable sequence that stays connected to the source as long as there is at least one subscription to the observable sequence.
OperationRefCount() - Constructor for class rx.operators.OperationRefCount
 
OperationReplay - Class in rx.operators
Replay with limited buffer and/or time constraints.
OperationReplay.CustomReplaySubject<TInput,TIntermediate,TResult> - Class in rx.operators
A customizable replay subject with support for transformations.
OperationReplay.CustomReplaySubjectSubscribeFunc<TIntermediate,TResult> - Class in rx.operators
The subscription function.
OperationReplay.CustomReplaySubjectSubscribeFunc(OperationReplay.ReplayState<TIntermediate, TResult>) - Constructor for class rx.operators.OperationReplay.CustomReplaySubjectSubscribeFunc
 
OperationReplay.SubjectWrapper<T> - Class in rx.operators
A subject that wraps another subject.
OperationReplay.SubjectWrapper(Observable.OnSubscribe<T>, Subject<T, T>) - Constructor for class rx.operators.OperationReplay.SubjectWrapper
 
OperationReplay.VirtualArrayList<T> - Class in rx.operators
Behaves like a normal, unbounded ArrayList but with virtual index.
OperationReplay.VirtualArrayList() - Constructor for class rx.operators.OperationReplay.VirtualArrayList
 
OperationReplay.VirtualBoundedList<T> - Class in rx.operators
A bounded list which increases its size up to a maximum capacity, then behaves like a circular buffer with virtual indexes.
OperationReplay.VirtualBoundedList(int) - Constructor for class rx.operators.OperationReplay.VirtualBoundedList
Construct a VirtualBoundedList with the given maximum number of elements.
OperationReplay.VirtualList<T> - Interface in rx.operators
Base interface for logically indexing a list.
OperationSample - Class in rx.operators
Returns an Observable that emits the results of sampling the items emitted by the source Observable at a specified time interval.
OperationSample() - Constructor for class rx.operators.OperationSample
 
OperationSample.SampleWithObservable<T,U> - Class in rx.operators
Sample with the help of another observable.
OperationSample.SampleWithObservable(Observable<T>, Observable<U>) - Constructor for class rx.operators.OperationSample.SampleWithObservable
 
OperationSequenceEqual - Class in rx.operators
Returns an Observable that emits a Boolean value that indicate whether two sequences are equal by comparing the elements pairwise.
OperationSequenceEqual() - Constructor for class rx.operators.OperationSequenceEqual
 
OperationSingle - Class in rx.operators
If the Observable completes after emitting a single item that matches a predicate, return an Observable containing that item.
OperationSingle() - Constructor for class rx.operators.OperationSingle
 
OperationSkip - Class in rx.operators
Returns an Observable that skips the first num items emitted by the source Observable.
OperationSkip() - Constructor for class rx.operators.OperationSkip
 
OperationSkip.SkipTimed<T> - Class in rx.operators
Skip the items after subscription for the given duration.
OperationSkip.SkipTimed(Observable<? extends T>, long, TimeUnit, Scheduler) - Constructor for class rx.operators.OperationSkip.SkipTimed
 
OperationSkipLast - Class in rx.operators
Bypasses a specified number of elements at the end of an observable sequence.
OperationSkipLast() - Constructor for class rx.operators.OperationSkipLast
 
OperationSkipLast.SkipLastTimed<T> - Class in rx.operators
Skip delivering values in the time window before the values.
OperationSkipLast.SkipLastTimed(Observable<? extends T>, long, TimeUnit, Scheduler) - Constructor for class rx.operators.OperationSkipLast.SkipLastTimed
 
OperationSkipUntil<T,U> - Class in rx.operators
Skip elements from the source Observable until the secondary observable fires an element.
OperationSkipUntil(Observable<T>, Observable<U>) - Constructor for class rx.operators.OperationSkipUntil
 
OperationSum - Class in rx.operators
A few operators for implementing the sum operation.
OperationSum() - Constructor for class rx.operators.OperationSum
 
OperationSwitch - Class in rx.operators
Transforms an Observable that emits Observables into a single Observable that emits the items emitted by the most recently published of those Observables.
OperationSwitch() - Constructor for class rx.operators.OperationSwitch
 
OperationTakeLast - Class in rx.operators
Returns an Observable that emits the last count items emitted by the source Observable.
OperationTakeLast() - Constructor for class rx.operators.OperationTakeLast
 
OperationTakeTimed - Class in rx.operators
Returns an Observable that emits the first num items emitted by the source Observable.
OperationTakeTimed() - Constructor for class rx.operators.OperationTakeTimed
 
OperationTakeTimed.TakeTimed<T> - Class in rx.operators
Takes values from the source until a timer fires.
OperationTakeTimed.TakeTimed(Observable<? extends T>, long, TimeUnit, Scheduler) - Constructor for class rx.operators.OperationTakeTimed.TakeTimed
 
OperationTakeUntil - Class in rx.operators
Returns an Observable that emits the items from the source Observable until another Observable emits an item.
OperationTakeUntil() - Constructor for class rx.operators.OperationTakeUntil
 
OperationTakeWhile - Class in rx.operators
Returns an Observable that emits items emitted by the source Observable as long as a specified condition is true.
OperationTakeWhile() - Constructor for class rx.operators.OperationTakeWhile
 
OperationThrottleFirst - Class in rx.operators
Throttle by windowing a stream and returning the first value in each window.
OperationThrottleFirst() - Constructor for class rx.operators.OperationThrottleFirst
 
OperationTimeInterval - Class in rx.operators
Records the time interval between consecutive elements in an observable sequence.
OperationTimeInterval() - Constructor for class rx.operators.OperationTimeInterval
 
OperationTimer - Class in rx.operators
Operation Timer with several overloads.
OperationTimer.TimerOnce - Class in rx.operators
Emit a single 0L after the specified time elapses.
OperationTimer.TimerOnce(long, TimeUnit, Scheduler) - Constructor for class rx.operators.OperationTimer.TimerOnce
 
OperationTimer.TimerPeriodically - Class in rx.operators
Emit 0L after the initial period and ever increasing number after each period.
OperationTimer.TimerPeriodically(long, long, TimeUnit, Scheduler) - Constructor for class rx.operators.OperationTimer.TimerPeriodically
 
OperationToFuture - Class in rx.operators
Returns a Future representing the single value emitted by an Observable.
OperationToFuture() - Constructor for class rx.operators.OperationToFuture
 
OperationToIterator - Class in rx.operators
Returns an Iterator that iterates over all items emitted by a specified Observable.
OperationToIterator() - Constructor for class rx.operators.OperationToIterator
 
OperationToMap - Class in rx.operators
Maps the elements of the source observable into a java.util.Map instance and emits that once the source observable completes.
OperationToMap() - Constructor for class rx.operators.OperationToMap
 
OperationToMap.DefaultToMapFactory<K,V> - Class in rx.operators
The default map factory.
OperationToMap.DefaultToMapFactory() - Constructor for class rx.operators.OperationToMap.DefaultToMapFactory
 
OperationToMap.ToMap<T,K,V> - Class in rx.operators
Maps the elements of the source observable into a java.util.Map instance returned by the mapFactory function by using the keySelector and valueSelector.
OperationToMap.ToMap(Observable<T>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, V>>) - Constructor for class rx.operators.OperationToMap.ToMap
 
OperationToMap.ToMap.ToMapObserver<K,V,T> - Class in rx.operators
Observer that collects the source values of T into a map.
OperationToMap.ToMap.ToMapObserver(Observer<? super Map<K, V>>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Map<K, V>) - Constructor for class rx.operators.OperationToMap.ToMap.ToMapObserver
 
OperationToMultimap - Class in rx.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.
OperationToMultimap() - Constructor for class rx.operators.OperationToMultimap
 
OperationToMultimap.DefaultMultimapCollectionFactory<K,V> - Class in rx.operators
The default collection factory for a key in the multimap returning an ArrayList independent of the key.
OperationToMultimap.DefaultMultimapCollectionFactory() - Constructor for class rx.operators.OperationToMultimap.DefaultMultimapCollectionFactory
 
OperationToMultimap.DefaultToMultimapFactory<K,V> - Class in rx.operators
The default multimap factory returning a HashMap.
OperationToMultimap.DefaultToMultimapFactory() - Constructor for class rx.operators.OperationToMultimap.DefaultToMultimapFactory
 
OperationToMultimap.ToMultimap<T,K,V> - Class in rx.operators
Maps the elements of the source observable int a multimap customized by various selectors and factories.
OperationToMultimap.ToMultimap(Observable<T>, 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.operators.OperationToMultimap.ToMultimap
 
OperationToMultimap.ToMultimap.ToMultimapObserver<T,K,V> - Class in rx.operators
Observer that collects the source values of Ts into a multimap.
OperationToMultimap.ToMultimap.ToMultimapObserver(Observer<? super Map<K, Collection<V>>>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Map<K, Collection<V>>, Func1<? super K, ? extends Collection<V>>) - Constructor for class rx.operators.OperationToMultimap.ToMultimap.ToMultimapObserver
 
OperationToObservableFuture - Class in rx.operators
Converts a Future into an Observable.
OperationToObservableFuture() - Constructor for class rx.operators.OperationToObservableFuture
 
OperationUsing - Class in rx.operators
Constructs an observable sequence that depends on a resource object.
OperationUsing() - Constructor for class rx.operators.OperationUsing
 
OperationWindow - Class in rx.operators
 
OperationWindow() - Constructor for class rx.operators.OperationWindow
 
OperationWindow.Window<T> - Class in rx.operators
This class represents a single window: A sequence of recorded values.
OperationWindow.Window() - Constructor for class rx.operators.OperationWindow.Window
 
OperatorAmb<T> - Class in rx.operators
Propagates the observable sequence that reacts first.
OperatorCast<T,R> - Class in rx.operators
Converts the elements of an observable sequence to the specified type.
OperatorCast(Class<R>) - Constructor for class rx.operators.OperatorCast
 
OperatorDoOnEach<T> - Class in rx.operators
Converts the elements of an observable sequence to the specified type.
OperatorDoOnEach(Observer<? super T>) - Constructor for class rx.operators.OperatorDoOnEach
 
OperatorElementAt<T> - Class in rx.operators
Returns the element at a specified index in a sequence.
OperatorElementAt(int) - Constructor for class rx.operators.OperatorElementAt
 
OperatorElementAt(int, T) - Constructor for class rx.operators.OperatorElementAt
 
OperatorFilter<T> - Class in rx.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.operators.OperatorFilter
 
OperatorGroupBy<K,T> - Class in rx.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.operators.OperatorGroupBy
 
OperatorMap<T,R> - Class in rx.operators
Applies a function of your choosing to every item emitted by an Observable, and returns this transformation as a new Observable.
OperatorMap(Func1<? super T, ? extends R>) - Constructor for class rx.operators.OperatorMap
 
OperatorMerge<T> - Class in rx.operators
Flattens a list of Observables into one Observable sequence, without any transformation.
OperatorMerge() - Constructor for class rx.operators.OperatorMerge
 
OperatorObserveOn<T> - Class in rx.operators
Delivers events on the specified Scheduler asynchronously via an unbounded buffer.
OperatorObserveOn(Scheduler) - Constructor for class rx.operators.OperatorObserveOn
 
OperatorObserveOnBounded<T> - Class in rx.operators
Delivers events on the specified Scheduler.
OperatorObserveOnBounded(Scheduler, int) - Constructor for class rx.operators.OperatorObserveOnBounded
 
OperatorObserveOnBounded(Scheduler) - Constructor for class rx.operators.OperatorObserveOnBounded
 
OperatorOnErrorFlatMap<T> - Class in rx.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.operators.OperatorOnErrorFlatMap
 
OperatorOnErrorResumeNextViaFunction<T> - Class in rx.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.operators.OperatorOnErrorResumeNextViaFunction
 
OperatorParallel<T,R> - Class in rx.operators
Identifies unit of work that can be executed in parallel on a given Scheduler.
OperatorParallel(Func1<Observable<T>, Observable<R>>, Scheduler) - Constructor for class rx.operators.OperatorParallel
 
OperatorPivot<K1,K2,T> - Class in rx.operators
 
OperatorPivot() - Constructor for class rx.operators.OperatorPivot
 
OperatorRepeat<T> - Class in rx.operators
 
OperatorRepeat(long, Scheduler) - Constructor for class rx.operators.OperatorRepeat
 
OperatorRepeat(Scheduler) - Constructor for class rx.operators.OperatorRepeat
 
OperatorRepeat(long) - Constructor for class rx.operators.OperatorRepeat
 
OperatorRepeat() - Constructor for class rx.operators.OperatorRepeat
 
OperatorRetry<T> - Class in rx.operators
 
OperatorRetry(int) - Constructor for class rx.operators.OperatorRetry
 
OperatorRetry() - Constructor for class rx.operators.OperatorRetry
 
OperatorScan<R,T> - Class in rx.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.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.operators.OperatorScan
Applies an accumulator function over an observable sequence and returns each intermediate result with the specified source and accumulator.
OperatorSerialize<T> - Class in rx.operators
 
OperatorSerialize() - Constructor for class rx.operators.OperatorSerialize
 
OperatorSkip<T> - Class in rx.operators
Returns an Observable that skips the first num items emitted by the source Observable.
OperatorSkip(int) - Constructor for class rx.operators.OperatorSkip
 
OperatorSkipWhile<T> - Class in rx.operators
Skips any emitted source items as long as the specified condition holds true.
OperatorSkipWhile(Func2<? super T, Integer, Boolean>) - Constructor for class rx.operators.OperatorSkipWhile
 
OperatorSubscribeOn<T> - Class in rx.operators
Subscribes Observers on the specified Scheduler.
OperatorSubscribeOn(Scheduler) - Constructor for class rx.operators.OperatorSubscribeOn
 
OperatorSynchronize<T> - Class in rx.operators
Wraps an Observable in another Observable that ensures that the resulting Observable is chronologically well-behaved.
OperatorSynchronize(Object) - Constructor for class rx.operators.OperatorSynchronize
 
OperatorSynchronize() - Constructor for class rx.operators.OperatorSynchronize
 
OperatorTake<T> - Class in rx.operators
Returns an Observable that emits the first num items emitted by the source Observable.
OperatorTake(int) - Constructor for class rx.operators.OperatorTake
 
OperatorTimeout<T> - Class in rx.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.operators.OperatorTimeout
 
OperatorTimeoutWithSelector<T,U,V> - Class in rx.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.operators.OperatorTimeoutWithSelector
 
OperatorTimestamp<T> - Class in rx.operators
Wraps each item emitted by a source Observable in a Timestamped object.
OperatorTimestamp(Scheduler) - Constructor for class rx.operators.OperatorTimestamp
 
OperatorToObservableList<T> - Class in rx.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.operators.OperatorToObservableList
 
OperatorToObservableSortedList<T> - Class in rx.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.operators.OperatorToObservableSortedList
 
OperatorToObservableSortedList(Func2<? super T, ? super T, Integer>) - Constructor for class rx.operators.OperatorToObservableSortedList
 
OperatorUnsubscribeOn<T> - Class in rx.operators
Unsubscribes on the specified Scheduler.
OperatorUnsubscribeOn(Scheduler) - Constructor for class rx.operators.OperatorUnsubscribeOn
 
OperatorZip<R> - Class in rx.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.operators.OperatorZip
 
OperatorZip(Func2) - Constructor for class rx.operators.OperatorZip
 
OperatorZip(Func3) - Constructor for class rx.operators.OperatorZip
 
OperatorZip(Func4) - Constructor for class rx.operators.OperatorZip
 
OperatorZip(Func5) - Constructor for class rx.operators.OperatorZip
 
OperatorZip(Func6) - Constructor for class rx.operators.OperatorZip
 
OperatorZip(Func7) - Constructor for class rx.operators.OperatorZip
 
OperatorZip(Func8) - Constructor for class rx.operators.OperatorZip
 
OperatorZip(Func9) - Constructor for class rx.operators.OperatorZip
 
OperatorZipIterable<T1,T2,R> - Class in rx.operators
 
OperatorZipIterable(Iterable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Constructor for class rx.operators.OperatorZipIterable
 
other - Variable in class rx.operators.OperationSkipUntil
 

P

parallel(Func1<Observable<T>, Observable<R>>) - Method in class rx.Observable
Perform work on the source Observable<T> in parallel by sharding it on a Schedulers.computation() Scheduler, and return the resulting Observable<R>.
parallel(Func1<Observable<T>, Observable<R>>, Scheduler) - Method in class rx.Observable
Perform work on the source Observable<T> in parallel by sharding it on a Scheduler, and return the resulting Observable<R>.
parallelMerge(Observable<Observable<T>>, int) - Static method in class rx.Observable
Converts an Observable<Observable<T>> into another Observable<Observable<T>> whose emitted Observables emit the same items, but the number of such Observables is restricted by parallelObservables.
parallelMerge(Observable<Observable<T>>, int, Scheduler) - Static method in class rx.Observable
Converts an Observable<Observable<T>> into another Observable<Observable<T>> whose emitted Observables emit the same items, but the number of such Observables is restricted by parallelObservables, and each runs on a defined Scheduler.
parallelMerge(Observable<Observable<T>>, int) - Static method in class rx.operators.OperationParallelMerge
 
parallelMerge(Observable<Observable<T>>, int, Scheduler) - Static method in class rx.operators.OperationParallelMerge
 
Pattern - Interface in rx.joins
Base interface for join patterns.
Pattern1<T1> - Class in rx.joins
Represents a join pattern over one observable sequence.
Pattern1(Observable<T1>) - Constructor for class rx.joins.Pattern1
 
Pattern2<T1,T2> - Class in rx.joins
Represents a join pattern over observable sequences.
Pattern2(Observable<T1>, Observable<T2>) - Constructor for class rx.joins.Pattern2
 
Pattern3<T1,T2,T3> - Class in rx.joins
Represents a join pattern over observable sequences.
Pattern3(Observable<T1>, Observable<T2>, Observable<T3>) - Constructor for class rx.joins.Pattern3
 
pivot(Observable<GroupedObservable<K1, GroupedObservable<K2, T>>>) - Static method in class rx.Observable
Pivot GroupedObservable streams without serializing/synchronizing to a single stream first.
Plan0<R> - Class in rx.joins
Represents an execution plan for join patterns.
Plan0() - Constructor for class rx.joins.Plan0
 
Plan1<T1,R> - Class in rx.joins
Represents an execution plan for join patterns.
Plan1(Pattern1<T1>, Func1<T1, R>) - Constructor for class rx.joins.Plan1
 
Plan2<T1,T2,R> - Class in rx.joins
Represents an execution plan for join patterns.
Plan2(Pattern2<T1, T2>, Func2<T1, T2, R>) - Constructor for class rx.joins.Plan2
 
Plan3<T1,T2,T3,R> - Class in rx.joins
Represents an execution plan for join patterns.
Plan3(Pattern3<T1, T2, T3>, Func3<T1, T2, T3, R>) - Constructor for class rx.joins.Plan3
 
propagate(Throwable) - Static method in class rx.exceptions.Exceptions
 
publish() - Method in class rx.Observable
Returns a ConnectableObservable, which waits until its connect method is called before it begins emitting items to those Observers that have subscribed to it.
publish(Func1<? super Observable<T>, ? extends Observable<R>>) - Method in class rx.Observable
Returns an Observable that emits the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the underlying sequence.
publish(Func1<? super Observable<T>, ? extends Observable<R>>, T) - Method in class rx.Observable
Returns an Observable that emits initialValue followed by the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable.
publish(T) - Method in class rx.Observable
Returns an Observable that emits initialValue followed by the items emitted by a ConnectableObservable that shares a single subscription to the source Observable.
publish - Variable in class rx.operators.OperationGroupByUntil.GroupSubject
 
publishLast() - Method in class rx.Observable
Returns a ConnectableObservable that emits only the last item emitted by the source Observable.
publishLast(Func1<? super Observable<T>, ? extends Observable<R>>) - Method in class rx.Observable
Returns an Observable that emits an item that results from invoking a specified selector on the last item emitted by a ConnectableObservable that shares a single subscription to the source Observable.
PublishSubject<T> - Class in rx.subjects
Subject that, once and Observer has subscribed, publishes all subsequent events to the subscriber.
PublishSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>, AtomicReference<Notification<T>>) - Constructor for class rx.subjects.PublishSubject
 
pushValue(T) - Method in class rx.operators.ChunkedOperation.Chunk
Appends a specified value to the ChunkedOperation.Chunk.
pushValue(T) - Method in class rx.operators.ChunkedOperation.Chunks
This method pushes a value to all not yet emitted ChunkedOperation.Chunk objects.
pushValue(T) - Method in class rx.operators.ChunkedOperation.NonOverlappingChunks
 
pushValue(T) - Method in class rx.operators.ChunkedOperation.SizeBasedChunks
 
pushValue(T) - Method in class rx.operators.ChunkedOperation.TimeAndSizeBasedChunks
 

Q

queue() - Method in class rx.joins.JoinObserver1
 

R

range(int, int) - Static method in class rx.Observable
Returns an Observable that emits a sequence of Integers within a specified range.
range(int, int, Scheduler) - Static method in class rx.Observable
Returns an Observable that emits a sequence of Integers within a specified range, on a specified Scheduler.
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 sequence that stays connected to the source as long as there is at least one subscription to the observable sequence.
refCount(ConnectableObservable<T>) - Static method in class rx.operators.OperationRefCount
 
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
Create a RefCountSubscription by wrapping the given non-null Subscription.
registerDefaultSchedulers(RxJavaDefaultSchedulers) - Method in class rx.plugins.RxJavaPlugins
Register a RxJavaDefaultSchedulers implementation as a global override of any injected or default implementations.
registerErrorHandler(RxJavaErrorHandler) - Method in class rx.plugins.RxJavaPlugins
Register a RxJavaErrorHandler implementation as a global override of any injected or default implementations.
registerObservableExecutionHook(RxJavaObservableExecutionHook) - Method in class rx.plugins.RxJavaPlugins
Register a RxJavaObservableExecutionHook implementation as a global override of any injected or default implementations.
remove(Subscription) - Method in class rx.subscriptions.CompositeSubscription
 
removeBefore(int) - Method in class rx.operators.OperationReplay.VirtualArrayList
 
removeBefore(int) - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
removeBefore(int) - Method in interface rx.operators.OperationReplay.VirtualList
Remove elements up before the given logical index and move the start() to this index.
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.
replay() - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the underlying Observable that will replay all of its items and notifications to any future Observer.
replay(Func1<? super Observable<T>, ? extends Observable<R>>) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on the items emitted by a ConnectableObservable that shares a single subscription to the source Observable.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, int) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying bufferSize notifications.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying no more than bufferSize items that were emitted within a specified time window.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying no more than bufferSize items that were emitted within a specified time window.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, Scheduler) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying a maximum of bufferSize items.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying all items that were emitted within a specified time window.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable, replaying all items that were emitted within a specified time window.
replay(Func1<? super Observable<T>, ? extends Observable<R>>, Scheduler) - Method in class rx.Observable
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a ConnectableObservable that shares a single subscription to the source Observable.
replay(int) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable that replays at most bufferSize items emitted by that Observable.
replay(int, long, TimeUnit) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and replays at most bufferSize items that were emitted during a specified time window.
replay(int, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and that replays a maximum of bufferSize items that are emitted within a specified time window.
replay(int, Scheduler) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and replays at most bufferSize items emitted by that Observable.
replay(long, TimeUnit) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and replays all items emitted by that Observable within a specified time window.
replay(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable and replays all items emitted by that Observable within a specified time window.
replay(Scheduler) - Method in class rx.Observable
Returns a ConnectableObservable that shares a single subscription to the source Observable that will replay all of its items and notifications to any future Observer on the given Scheduler.
replayBuffered(int) - Static method in class rx.operators.OperationReplay
Create a BoundedReplaySubject with the given buffer size.
ReplaySubject<T> - Class in rx.subjects
Subject that retains all events and will replay them to an Observer that subscribes.
ReplaySubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>, ReplaySubject.ReplayState<T>) - Constructor for class rx.subjects.ReplaySubject
 
replayValues() - Method in class rx.operators.OperationReplay.CustomReplaySubject
Replay values up to the current index.
replayWindowed(long, TimeUnit, int, Scheduler) - Static method in class rx.operators.OperationReplay
Create a CustomReplaySubject with the given time window length and optional buffer size.
reset() - Method in class rx.operators.OperationReplay.VirtualArrayList
 
reset() - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
reset() - Method in interface rx.operators.OperationReplay.VirtualList
Clears and resets the indexes of the list.
resultSelector - Variable in class rx.operators.OperationGroupJoin
 
retry() - Method in class rx.Observable
Return an Observable that mirrors the source Observable, resubscribing to it if it calls onError (infinite retry count).
retry(int) - Method in class rx.Observable
Return an Observable that mirrors the source Observable, resubscribing to it if it calls onError up to a specified number of retries.
returnNull() - Static method in class rx.functions.Functions
 
right - Variable in class rx.operators.OperationGroupJoin
 
rightDuration - Variable in class rx.operators.OperationGroupJoin
 
rx - package rx
Rx Observables
rx.exceptions - package rx.exceptions
 
rx.functions - package rx.functions
 
rx.joins - package rx.joins
 
rx.observables - package rx.observables
 
rx.observers - package rx.observers
 
rx.operators - package rx.operators
Operators that allow composing Observables to transform and manipulate data in an asynchronous, functional and thread-safe manner.
rx.plugins - package rx.plugins
 
rx.schedulers - package rx.schedulers
Rx Schedulers
rx.subjects - package rx.subjects
 
rx.subscriptions - package rx.subscriptions
 
rx.util.functions - package rx.util.functions
 
RxJavaDefaultSchedulers - Class in rx.plugins
Define alternate Scheduler implementations to be returned by the Schedulers factory methods.
RxJavaDefaultSchedulers() - Constructor for class rx.plugins.RxJavaDefaultSchedulers
 
RxJavaErrorHandler - Class in rx.plugins
Abstract class for defining error handling logic in addition to the normal Observer.onError(Throwable) behavior.
RxJavaErrorHandler() - Constructor for class rx.plugins.RxJavaErrorHandler
 
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 See the RxJava GitHub Wiki for more information: https://github.com/Netflix/RxJava/wiki/Plugins.

S

SafeObservableSubscription - Class in rx.operators
Deprecated. since `Observer` now implements `Subscription` and `CompositeSubscription` etc handle these things
SafeObservableSubscription() - Constructor for class rx.operators.SafeObservableSubscription
Deprecated.  
SafeObservableSubscription(Subscription) - Constructor for class rx.operators.SafeObservableSubscription
Deprecated.  
SafeObserver<T> - Class in rx.operators
Deprecated. replaced by SafeSubscriber
SafeObserver(Observer<? super T>) - Constructor for class rx.operators.SafeObserver
Deprecated.  
SafeObserver(SafeObservableSubscription, Observer<? super T>) - Constructor for class rx.operators.SafeObserver
Deprecated.  
SafeSubscriber<T> - Class in rx.observers
Wrapper around Observer to ensure compliance with 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 results of sampling the items emitted by the source Observable at a specified time interval.
sample(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits the results of sampling the items emitted by the source Observable at a specified time interval.
sample(Observable<U>) - Method in class rx.Observable
Return an Observable that emits the results of sampling the items emitted by the source Observable whenever the specified sampler Observable emits an item or completes.
sample(Observable<? extends T>, long, TimeUnit) - Static method in class rx.operators.OperationSample
Samples the observable sequence at each interval.
sample(Observable<? extends T>, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationSample
Samples the observable sequence at each interval.
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(Action1<Scheduler.Inner>, long, TimeUnit) - Method in class rx.Scheduler.Inner
Schedules an action to be executed in delayTime.
schedule(Action1<Scheduler.Inner>) - Method in class rx.Scheduler.Inner
Schedules a cancelable action to be executed in delayTime.
schedule() - Method in class rx.Scheduler.Recurse
Schedule the current function for execution immediately.
schedule(long, TimeUnit) - Method in class rx.Scheduler.Recurse
Schedule the current function for execution in the future.
schedule(Action1<Scheduler.Inner>) - Method in class rx.Scheduler
Schedules an Action on a new Scheduler instance (typically another thread) for execution.
schedule(Action1<Scheduler.Inner>, long, TimeUnit) - Method in class rx.Scheduler
Schedules an Action on a new Scheduler instance (typically another thread) for execution at some point in the future.
schedule(Action1<Scheduler.Inner>) - Method in class rx.schedulers.ExecutorScheduler
 
schedule(Action1<Scheduler.Inner>, long, TimeUnit) - Method in class rx.schedulers.ExecutorScheduler
 
schedule(Action1<Scheduler.Inner>) - Method in class rx.schedulers.ImmediateScheduler
 
schedule(Action1<Scheduler.Inner>, long, TimeUnit) - Method in class rx.schedulers.ImmediateScheduler
 
schedule(Action1<Scheduler.Inner>) - Method in class rx.schedulers.NewThreadScheduler
 
schedule(Action1<Scheduler.Inner>, long, TimeUnit) - Method in class rx.schedulers.NewThreadScheduler
 
schedule(Action1<Scheduler.Inner>, long, TimeUnit) - Method in class rx.schedulers.TestScheduler
 
schedule(Action1<Scheduler.Inner>) - Method in class rx.schedulers.TestScheduler
 
schedule(Action1<Scheduler.Inner>) - Method in class rx.schedulers.TrampolineScheduler
 
schedule(Action1<Scheduler.Inner>, long, TimeUnit) - Method in class rx.schedulers.TrampolineScheduler
 
schedulePeriodically(Action1<Scheduler.Inner>, long, long, TimeUnit) - Method in class rx.Scheduler
Schedules a cancelable action to be executed periodically.
schedulePeriodically(Action1<Scheduler.Inner>, long, long, TimeUnit) - Method in class rx.schedulers.ExecutorScheduler
 
Scheduler - Class in rx
Represents an object that schedules units of work.
Scheduler() - Constructor for class rx.Scheduler
 
Scheduler.Inner - Class in rx
 
Scheduler.Inner() - Constructor for class rx.Scheduler.Inner
 
Scheduler.Recurse - Class in rx
 
scheduleRecursive(Action1<Scheduler.Recurse>) - Method in class rx.Scheduler
 
Schedulers - Class in rx.schedulers
Static factory methods for creating Schedulers.
second() - Method in class rx.joins.Pattern2
 
second() - Method in class rx.joins.Pattern3
 
selector - Variable in class rx.joins.Plan1
 
selector() - Method in class rx.joins.Plan1
 
selector - Variable in class rx.joins.Plan2
 
selector - Variable in class rx.joins.Plan3
 
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.
sequenceEqual(Observable<? extends T>, Observable<? extends T>, Func2<? super T, ? super T, Boolean>) - Static method in class rx.operators.OperationSequenceEqual
 
serialize() - Method in class rx.Observable
 
SerializedObserver<T> - Class in rx.observers
Enforce single-threaded, serialized, ordered execution of onNext, onCompleted, onError.
SerializedObserver(Observer<? super T>) - Constructor for class rx.observers.SerializedObserver
 
SerializedSubscriber<T> - Class in rx.observers
Enforce single-threaded, serialized, ordered execution of onNext, onCompleted, onError.
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
 
set(Subscription) - Method in class rx.subscriptions.SerialSubscription
 
setSubscription(Subscription) - Method in class rx.subscriptions.MultipleAssignmentSubscription
Deprecated. 
setSubscription(Subscription) - Method in class rx.subscriptions.SerialSubscription
Deprecated. 
single() - Method in class rx.Observable
If the source Observable completes after emitting a single item, return an Observable that emits that item.
single(Func1<? super T, Boolean>) - Method in class rx.Observable
If the Observable completes after emitting a single item that matches a specified predicate, return an Observable that emits that item.
single() - Method in class rx.observables.BlockingObservable
If the Observable completes after emitting a single item, return that item, otherwise throw an IllegalArgumentException.
single(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
If the Observable completes after emitting a single item that matches a given predicate, return that item, otherwise throw an IllegalArgumentException.
single(Observable<? extends T>) - Static method in class rx.operators.OperationSingle
 
singleOrDefault(T) - Method in class rx.Observable
If the source Observable completes after emitting a single item, return an Observable that emits that item; if the source Observable is empty, return an Observable that emits a default item.
singleOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.Observable
If the Observable completes after emitting a single item that matches a predicate, return an Observable that emits that item; if the source Observable emits no such item, return an Observable that emits a default item.
singleOrDefault(T) - Method in class rx.observables.BlockingObservable
If the Observable 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 the Observable 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.
singleOrDefault(Observable<? extends T>, T) - Static method in class rx.operators.OperationSingle
 
size() - Method in class rx.operators.ChunkedOperation.Chunk
 
size() - Method in class rx.operators.OperationReplay.VirtualArrayList
 
size() - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
size() - Method in interface rx.operators.OperationReplay.VirtualList
 
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.
skipLast(Observable<? extends T>, int) - Static method in class rx.operators.OperationSkipLast
Bypasses a specified number of elements at the end of an observable sequence.
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.
source - Variable in class rx.operators.OperationSkipUntil
 
start() - Method in class rx.operators.OperationReplay.VirtualArrayList
 
start() - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
start() - Method in interface rx.operators.OperationReplay.VirtualList
Returns the current head index of this list.
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(Iterable<T>, Scheduler) - Method in class rx.Observable
Returns an Observable that emits the items in a specified Iterable, on a specified Scheduler, 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.
startWith(T[], Scheduler) - Method in class rx.Observable
Returns an Observable that emits the items from a specified array, on a specified Scheduler, before it begins to emit items emitted by the source Observable.
state - Variable in class rx.operators.OperationReplay.CustomReplaySubject
The replay state.
stop() - Method in interface rx.operators.ChunkedOperation.ChunkCreator
Signifies a onCompleted or onError event.
stop() - Method in class rx.operators.ChunkedOperation.ObservableBasedMultiChunkCreator
 
stop() - Method in class rx.operators.ChunkedOperation.ObservableBasedSingleChunkCreator
 
stop() - Method in class rx.operators.ChunkedOperation.SingleChunkCreator
 
stop() - Method in class rx.operators.ChunkedOperation.SkippingChunkCreator
 
stop() - Method in class rx.operators.ChunkedOperation.TimeBasedChunkCreator
 
Subject<T,R> - Class in rx.subjects
 
Subject(Observable.OnSubscribe<R>) - Constructor for class rx.subjects.Subject
 
subscribe(Object) - Method in interface rx.joins.JoinObserver
 
subscribe(Object) - Method in class rx.joins.JoinObserver1
 
subscribe() - Method in class rx.Observable
Subscribe and ignore all events.
subscribe(Action1<? super T>) - Method in class rx.Observable
An Observer must call an Observable's subscribe method in order to receive items and notifications from the Observable.
subscribe(Action1<? super T>, Action1<Throwable>) - Method in class rx.Observable
An Observer must call an Observable's subscribe method in order to receive items and notifications from the Observable.
subscribe(Action1<? super T>, Action1<Throwable>, Action0) - Method in class rx.Observable
An Observer must call an Observable's subscribe method in order to receive items and notifications from the Observable.
subscribe(Action1<? super T>, Action1<Throwable>, Action0, Scheduler) - Method in class rx.Observable
An Observer must call an Observable's subscribe method in order to receive items and notifications from the Observable.
subscribe(Action1<? super T>, Action1<Throwable>, Scheduler) - Method in class rx.Observable
An Observer must call an Observable's subscribe method in order to receive items and notifications from the Observable.
subscribe(Action1<? super T>, Scheduler) - Method in class rx.Observable
An Observer must call an Observable's subscribe method in order to receive items and notifications from the Observable.
subscribe(Observer<? super T>, Scheduler) - Method in class rx.Observable
An Observer must subscribe to an Observable in order to receive items and notifications from the Observable.
subscribe(Observer<? super T>) - Method in class rx.Observable
An Observer must subscribe to an Observable in order to receive items and notifications from the Observable.
subscribe(Subscriber<? super T>) - Method in class rx.Observable
A Subscriber must call an Observable's subscribe method in order to receive items and notifications from the Observable.
subscribe(Subscriber<? super T>, Scheduler) - Method in class rx.Observable
A Subscriber must call an Observable's subscribe method in order to receive items and notifications from the Observable.
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.
Subscriber(CompositeSubscription) - Constructor for class rx.Subscriber
 
Subscriber() - Constructor for class rx.Subscriber
 
Subscriber(Subscriber<?>) - Constructor for class rx.Subscriber
 
subscriberOf(Observable<T>) - Static method in class rx.operators.OperationReplay
Return an OnSubscribeFunc which delegates the subscription to the given observable.
Subscribers - Class in rx.observers
 
Subscribers() - Constructor for class rx.observers.Subscribers
 
Subscription - Interface in rx
Subscription returns from Observable.subscribe(Subscriber) to allow unsubscribing.
Subscriptions - Class in rx.subscriptions
Helper methods and utilities for creating and working with Subscription objects
Subscriptions() - Constructor for class rx.subscriptions.Subscriptions
 
sumAtLeastOneDoubles(Observable<Double>) - Static method in class rx.operators.OperationSum
 
sumAtLeastOneFloats(Observable<Float>) - Static method in class rx.operators.OperationSum
 
sumAtLeastOneIntegers(Observable<Integer>) - Static method in class rx.operators.OperationSum
 
sumAtLeastOneLongs(Observable<Long>) - Static method in class rx.operators.OperationSum
 
sumDouble(Observable<Double>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
sumDouble(Func1<? super T, Double>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
sumDoubles(Observable<Double>) - Static method in class rx.operators.OperationSum
 
sumFloat(Observable<Float>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
sumFloat(Func1<? super T, Float>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
sumFloats(Observable<Float>) - Static method in class rx.operators.OperationSum
 
sumInteger(Observable<Integer>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
sumInteger(Func1<? super T, Integer>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
sumIntegers(Observable<Integer>) - Static method in class rx.operators.OperationSum
 
sumLong(Observable<Long>) - Static method in class rx.Observable
Deprecated. Use rxjava-math module instead
sumLong(Func1<? super T, Long>) - Method in class rx.Observable
Deprecated. Use rxjava-math module instead
sumLongs(Observable<Long>) - Static method in class rx.operators.OperationSum
 
switchDo(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Deprecated. use Observable.switchOnNext(rx.Observable>)
switchDo(Observable<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationSwitch
This function transforms an Observable sequence of Observable sequences into a single Observable sequence which produces values from the most recently published Observable .
switchLatest(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Given an Observable that emits Observables, returns an Observable that emits the items emitted by the most recently emitted of those Observables.
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
Given an Observable that emits Observables, returns an Observable that emits the items emitted by the most recently emitted of those Observables.
synchronize(Observable<T>) - Static method in class rx.Observable
Deprecated. use Observable.synchronize() or Observable.synchronize(Object)
synchronize() - Method in class rx.Observable
Deprecated. Use Observable.serialize() instead as it doesn't block threads while emitting notification.
synchronize(Object) - Method in class rx.Observable
Deprecated. Use Observable.serialize() instead as it doesn't block threads while emitting notification.
SynchronizedObserver<T> - Class in rx.observers
Deprecated. Use SerializedObserver instead as it doesn't block threads during event notification.
SynchronizedObserver(Observer<? super T>) - Constructor for class rx.observers.SynchronizedObserver
Deprecated.  
SynchronizedObserver(Observer<? super T>, Object) - Constructor for class rx.observers.SynchronizedObserver
Deprecated.  
SynchronizedSubscriber<T> - Class in rx.observers
Deprecated. Use SerializedSubscriber instead as it doesn't block threads during event notification.
SynchronizedSubscriber(Subscriber<? super T>, Object) - Constructor for class rx.observers.SynchronizedSubscriber
Deprecated.  
SynchronizedSubscriber(Subscriber<? super T>) - Constructor for class rx.observers.SynchronizedSubscriber
Deprecated. Used when synchronizing an Subscriber without access to the subscription.

T

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.
take(Observable<? extends T>, int) - Static method in class rx.operators.OperationTakeTimed
Returns a specified number of contiguous values from the start of an observable sequence.
takeFirst() - Method in class rx.Observable
Deprecated. use take(1) directly
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
Return 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
Return 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
Return 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
Return 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.
takeLast(Observable<? extends T>, int) - Static method in class rx.operators.OperationTakeLast
 
takeLast(Observable<? extends T>, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationTakeLast
Returns the items emitted by source whose arrived in the time window before the source completed.
takeLast(Observable<? extends T>, int, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationTakeLast
Returns the items emitted by source whose arrived in the time window before the source completed and at most count values.
takeLastBuffer(int) - Method in class rx.Observable
Return 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
Return 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
Return 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
Return 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
Return an Observable that emits a single List containing those items from the source Observable that were emitted during a specified window of time before the source Observable completed, where the timing information is provided by the given Scheduler.
takeUntil(Observable<? extends E>) - Method in class rx.Observable
Returns an Observable that emits the items emitted by the source Observable until a second Observable emits an item.
takeUntil(Observable<? extends T>, Observable<? extends E>) - Static method in class rx.operators.OperationTakeUntil
Returns the values from the source observable sequence until the other observable sequence produces a value.
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.
takeWhile(Observable<? extends T>, Func1<? super T, Boolean>) - Static method in class rx.operators.OperationTakeWhile
Returns values from an observable sequence as long as a specified condition is true, and then skips the remaining values.
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.
takeWhileWithIndex(Observable<? extends T>, Func2<? super T, ? super Integer, Boolean>) - Static method in class rx.operators.OperationTakeWhile
Returns values from an observable sequence as long as a specified condition is true, and then skips the remaining values.
test() - Static method in class rx.schedulers.Schedulers
 
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
 
TestScheduler() - Constructor for class rx.schedulers.TestScheduler
 
TestSubject<T> - Class in rx.subjects
Subject that, once and Observer has subscribed, publishes all subsequent events to the subscriber.
TestSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>, AtomicReference<Notification<T>>, TestScheduler) - Constructor for class rx.subjects.TestSubject
 
TestSubscriber<T> - Class in rx.observers
Observer usable for unit testing to perform assertions, inspect received events or wrap a mocked Observer.
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
 
then(Func1<T1, R>) - Method in class rx.joins.Pattern1
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Func2<T1, T2, R>) - Method in class rx.joins.Pattern2
 
then(Func3<T1, T2, T3, R>) - Method in class rx.joins.Pattern3
 
then(Func1<T, R>) - Method in class rx.Observable
Matches when the Observable has an available item and projects the item by invoking the selector function.
then(Observable<T1>, Func1<T1, R>) - Static method in class rx.operators.OperationJoinPatterns
Matches when the observable sequence has an available element and projects the element by invoking the selector function.
third() - Method in class rx.joins.Pattern3
 
threadPoolForComputation() - Static method in class rx.schedulers.Schedulers
Deprecated. use Schedulers.computation()
threadPoolForIO() - Static method in class rx.schedulers.Schedulers
Deprecated. use Schedulers.io() instead
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.
throttleFirst(Observable<T>, long, TimeUnit) - Static method in class rx.operators.OperationThrottleFirst
Throttles to first value in each window.
throttleFirst(Observable<T>, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationThrottleFirst
Throttles to first value in each window.
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
 
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(Observable<? extends T>) - Static method in class rx.operators.OperationTimeInterval
 
timeInterval(Observable<? extends T>, Scheduler) - Static method in class rx.operators.OperationTimeInterval
 
TimeInterval<T> - Class in rx.schedulers
 
TimeInterval(long, T) - Constructor for class rx.schedulers.TimeInterval
 
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 don'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 don'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
Return 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
Return 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
 
toBlockingObservable() - Method in class rx.Observable
Converts an Observable into a BlockingObservable (an Observable with blocking operators).
toFunc(Action0) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action1<T1>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action2<T1, T2>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action3<T1, T2, T3>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action4<T1, T2, T3, T4>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action5<T1, T2, T3, T4, T5>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action6<T1, T2, T3, T4, T5, T6>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action7<T1, T2, T3, T4, T5, T6, T7>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action8<T1, T2, T3, T4, T5, T6, T7, T8>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action9<T1, T2, T3, T4, T5, T6, T7, T8, T9>) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(ActionN) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action0, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns the given result.
toFunc(Action1<T1>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action2<T1, T2>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action3<T1, T2, T3>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action4<T1, T2, T3, T4>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action5<T1, T2, T3, T4, T5>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action6<T1, T2, T3, T4, T5, T6>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action7<T1, T2, T3, T4, T5, T6, T7>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action8<T1, T2, T3, T4, T5, T6, T7, T8>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action9<T1, T2, T3, T4, T5, T6, T7, T8, T9>, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(ActionN, R) - Static method in class rx.functions.Actions
Convert an action to a function which calls the action returns Void (null).
toFunc(Action0) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action1<T1>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action2<T1, T2>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action3<T1, T2, T3>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action4<T1, T2, T3, T4>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action5<T1, T2, T3, T4, T5>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action6<T1, T2, T3, T4, T5, T6>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action7<T1, T2, T3, T4, T5, T6, T7>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action8<T1, T2, T3, T4, T5, T6, T7, T8>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action9<T1, T2, T3, T4, T5, T6, T7, T8, T9>) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(ActionN) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action0, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns the given result.
toFunc(Action1<T1>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action2<T1, T2>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action3<T1, T2, T3>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action4<T1, T2, T3, T4>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action5<T1, T2, T3, T4, T5>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action6<T1, T2, T3, T4, T5, T6>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action7<T1, T2, T3, T4, T5, T6, T7>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action8<T1, T2, T3, T4, T5, T6, T7, T8>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(Action9<T1, T2, T3, T4, T5, T6, T7, T8, T9>, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFunc(ActionN, R) - Static method in class rx.util.functions.Actions
Deprecated. Convert an action to a function which calls the action returns Void (null).
toFuture() - Method in class rx.observables.BlockingObservable
Returns a Future representing the single value emitted by an Observable.
toFuture(Observable<? extends T>) - Static method in class rx.operators.OperationToFuture
Returns a Future that expects a single item from the observable.
toIterable() - Method in class rx.observables.BlockingObservable
Converts an Observable into an Iterable.
toIterator(Observable<? extends T>) - Static method in class rx.operators.OperationToIterator
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.
toList() - Method in class rx.operators.OperationReplay.VirtualArrayList
 
toList() - Method in class rx.operators.OperationReplay.VirtualBoundedList
 
toList() - Method in interface rx.operators.OperationReplay.VirtualList
Returns the current content as a list.
toMap(Func1<? super T, ? extends K>) - Method in class rx.Observable
Return 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
Return 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
Return 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.
toMap(Observable<T>, Func1<? super T, ? extends K>) - Static method in class rx.operators.OperationToMap
ToMap with key selector, identity value selector and default HashMap factory.
toMap(Observable<T>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Static method in class rx.operators.OperationToMap
ToMap with key selector, value selector and default HashMap factory.
toMap(Observable<T>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, V>>) - Static method in class rx.operators.OperationToMap
ToMap with key selector, value selector and custom Map factory.
toMultimap(Func1<? super T, ? extends K>) - Method in class rx.Observable
Return 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
Return 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
Return 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
Return 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.
toMultimap(Observable<T>, Func1<? super T, ? extends K>) - Static method in class rx.operators.OperationToMultimap
ToMultimap with key selector, identitiy value selector, default HashMap factory and default ArrayList collection factory.
toMultimap(Observable<T>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Static method in class rx.operators.OperationToMultimap
ToMultimap with key selector, custom value selector, default HashMap factory and default ArrayList collection factory.
toMultimap(Observable<T>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>) - Static method in class rx.operators.OperationToMultimap
ToMultimap with key selector, custom value selector, custom Map factory and default ArrayList collection factory.
toMultimap(Observable<T>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>, Func1<? super K, ? extends Collection<V>>) - Static method in class rx.operators.OperationToMultimap
ToMultimap with key selector, custom value selector, custom Map factory and custom collection factory.
toObservable() - Method in class rx.operators.OperationGroupByUntil.GroupSubject
 
toObservableFuture(Future<? extends T>) - Static method in class rx.operators.OperationToObservableFuture
 
toObservableFuture(Future<? extends T>, long, TimeUnit) - Static method in class rx.operators.OperationToObservableFuture
 
toPredicate2(Func1<? super T, Boolean>) - Static method in class rx.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.Notification
 
toString() - Method in class rx.schedulers.TimeInterval
 
toString() - Method in class rx.schedulers.Timestamped
 
trampoline() - Static method in class rx.schedulers.Schedulers
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
 

U

unsubscribe() - Method in class rx.operators.ChunkedOperation.TimeAndSizeBasedChunks
 
unsubscribe() - Method in class rx.operators.ChunkedOperation.TimeBasedChunks
 
unsubscribe() - Method in class rx.operators.SafeObservableSubscription
Deprecated.  
unsubscribe() - Method in class rx.Subscriber
 
unsubscribe() - Method in interface rx.Subscription
Stop receiving notifications on the Subscriber that was registered when this Subscription was received.
unsubscribe() - Method in class rx.subscriptions.BooleanSubscription
 
unsubscribe() - Method in class rx.subscriptions.CompositeSubscription
 
unsubscribe() - Method in class rx.subscriptions.MultipleAssignmentSubscription
 
unsubscribe() - Method in class rx.subscriptions.RefCountSubscription
 
unsubscribe() - Method in class rx.subscriptions.SerialSubscription
 
unsubscribeOn(Scheduler) - Method in class rx.Observable
Asynchronously unsubscribes on the specified Scheduler.
using(Func0<RESOURCE>, Func1<RESOURCE, Observable<T>>) - Static method in class rx.Observable
Constructs an Observable that creates a dependent resource object.
using(Func0<RESOURCE>, Func1<RESOURCE, Observable<T>>) - Static method in class rx.operators.OperationUsing
 

V

valueOf(String) - Static method in enum rx.Notification.Kind
Returns the enum constant of this type with the specified name.
values() - Static method in enum rx.Notification.Kind
Returns an array containing the constants of this enum type, in the order they are declared.

W

when(Iterable<? extends Plan0<R>>) - Static method in class rx.Observable
Joins together the results from several patterns via their plans.
when(Plan0<R>...) - Static method in class rx.Observable
Joins together the results from several patterns via their plans.
when(Plan0<R>) - Static method in class rx.Observable
Joins the results from a pattern via its plan.
when(Plan0<R>, Plan0<R>) - Static method in class rx.Observable
Joins together the results from two patterns via their plans.
when(Plan0<R>, Plan0<R>, Plan0<R>) - Static method in class rx.Observable
Joins together the results from three patterns via their plans.
when(Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>) - Static method in class rx.Observable
Joins together the results from four patterns via their plans.
when(Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>) - Static method in class rx.Observable
Joins together the results from five patterns via their plans.
when(Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>) - Static method in class rx.Observable
Joins together the results from six patterns via their plans.
when(Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>) - Static method in class rx.Observable
Joins together the results from seven patterns via their plans.
when(Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>) - Static method in class rx.Observable
Joins together the results from eight patterns via their plans.
when(Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>, Plan0<R>) - Static method in class rx.Observable
Joins together the results from nine patterns via their plans.
when(Plan0<R>...) - Static method in class rx.operators.OperationJoinPatterns
Joins together the results from several patterns.
when(Iterable<? extends Plan0<R>>) - Static method in class rx.operators.OperationJoinPatterns
Joins together the results from several patterns.
where(Func1<? super T, Boolean>) - Method in class rx.Observable
Deprecated. use Observable.filter(Func1)
window(Func0<? extends Observable<? extends TClosing>>) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(int) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(int, int) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, TimeUnit) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, TimeUnit, int) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, TimeUnit, int, Scheduler) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(long, TimeUnit, Scheduler) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Method in class rx.Observable
Returns an Observable that emits windows of items it collects from the source Observable.
window(Observable<U>) - Method in class rx.Observable
Returns an Observable that emits non-overlapping windows of items it collects from the source Observable where the boundary of each window is determined by the items emitted from a specified boundary-governing Observable.
window(Observable<? extends T>, Func0<? extends Observable<? extends TClosing>>) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, int) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, int, int) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, long, TimeUnit) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, long, TimeUnit, int) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, long, TimeUnit, int, Scheduler) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, long, long, TimeUnit) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, long, long, TimeUnit, Scheduler) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, Observable<U>) - Static method in class rx.operators.OperationWindow
Emits windows of values of the source Observable where the window boundary is determined by the items of the boundary Observable.
windowMaker() - Static method in class rx.operators.OperationWindow
 
wrap(Subscription) - Method in class rx.operators.SafeObservableSubscription
Deprecated. Wraps the actual subscription once it exists (if it wasn't available when constructed)

Z

zip(Iterable<? extends Observable<?>>, FuncN<? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of items emitted, in sequence, by an Iterable of other Observables.
zip(Observable<? extends Observable<?>>, FuncN<? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of n items emitted, in sequence, by the n Observables emitted by a specified Observable.
zip(Observable<? extends T1>, Observable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of two items emitted, in sequence, by two other Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of three items emitted, in sequence, by three other Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Func4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of four items emitted, in sequence, by four other Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Func5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of five items emitted, in sequence, by five other Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Func6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of six items emitted, in sequence, by six other Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Func7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of seven items emitted, in sequence, by seven other Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Func8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of eight items emitted, in sequence, by eight other Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Observable<? extends T9>, Func9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class rx.Observable
Returns an Observable that emits the results of a function of your choosing applied to combinations of nine items emitted, in sequence, by nine other Observables.
zip(Iterable<? extends T2>, Func2<? super T, ? super T2, ? extends R>) - Method in class rx.Observable
Returns an Observable that emits items that are the result of applying a specified function to pairs of values, one each from the source Observable and a specified Iterable sequence.
zip(Observable<? extends T2>, Func2<? super T, ? super T2, ? extends R>) - Method in class rx.Observable
Returns an Observable that emits items that are the result of applying a specified function to pairs of values, one each from the source Observable and another specified Observable.

_

_onError(Throwable) - Method in class rx.observers.SafeSubscriber
 
_onError(Throwable) - Method in class rx.operators.SafeObserver
Deprecated.  

A B C D E F G H I J K L M N O P Q R S T U V W Z _