RxJava


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

A

Action - Interface in rx.util.functions
All Action interfaces extend from this.
Action0 - Interface in rx.util.functions
 
Action1<T1> - Interface in rx.util.functions
 
Action2<T1,T2> - Interface in rx.util.functions
 
Action3<T1,T2,T3> - Interface in rx.util.functions
 
add(Subscription) - Method in class rx.subscriptions.CompositeSubscription
 
advanceTimeBy(long, TimeUnit) - Method in class rx.concurrency.TestScheduler
 
advanceTimeTo(long, TimeUnit) - Method in class rx.concurrency.TestScheduler
 
aggregate(Func2<? super T, ? super T, ? extends T>) - Method in class rx.Observable
Synonymous with reduce().
aggregate(R, Func2<? super R, ? super T, ? extends R>) - Method in class rx.Observable
Synonymous with reduce().
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
 
alwaysTrue() - Static method in class rx.util.functions.Functions
 
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.OnSubscribeFunc<T>, ConcurrentHashMap<Subscription, Observer<? super T>>) - Constructor for class rx.subjects.AsyncSubject
 

B

BehaviorSubject<T> - Class in rx.subjects
Subject that publishes the most recent and all subsequent events to each subscribed Observer.
BehaviorSubject(AtomicReference<T>, Observable.OnSubscribeFunc<T>, ConcurrentHashMap<Subscription, Observer<? super 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 Closing>>) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(Observable<? extends Opening>, Func1<Opening, ? extends Observable<? extends Closing>>) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(int) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(int, int) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(long, TimeUnit) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(long, TimeUnit, Scheduler) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(long, TimeUnit, int) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(long, TimeUnit, int, Scheduler) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(long, long, TimeUnit) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(long, long, TimeUnit, Scheduler) - Method in class rx.Observable
Creates an Observable which produces buffers of collected values.
buffer(Observable<T>, Func0<? extends Observable<? extends Closing>>) - Static method in class rx.operators.OperationBuffer
This method creates a Func1 object which represents the buffer operation.
buffer(Observable<T>, Observable<? extends Opening>, Func1<Opening, ? extends Observable<? extends Closing>>) - 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.

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.util.functions.Action0
 
call(T1) - Method in interface rx.util.functions.Action1
 
call(T1, T2) - Method in interface rx.util.functions.Action2
 
call(T1, T2, T3) - Method in interface rx.util.functions.Action3
 
call() - Method in interface rx.util.functions.Func0
 
call(T1) - Method in interface rx.util.functions.Func1
 
call(T1, T2) - Method in interface rx.util.functions.Func2
 
call(T1, T2, T3) - Method in interface rx.util.functions.Func3
 
call(T1, T2, T3, T4) - Method in interface rx.util.functions.Func4
 
call(T1, T2, T3, T4, T5) - Method in interface rx.util.functions.Func5
 
call(T1, T2, T3, T4, T5, T6) - Method in interface rx.util.functions.Func6
 
call(T1, T2, T3, T4, T5, T6, T7) - Method in interface rx.util.functions.Func7
 
call(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface rx.util.functions.Func8
 
call(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface rx.util.functions.Func9
 
call(Object...) - Method in interface rx.util.functions.FuncN
 
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> - 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 Opening>, Func1<Opening, ? extends Observable<? extends Closing>>) - Constructor for class rx.operators.ChunkedOperation.ObservableBasedMultiChunkCreator
 
ChunkedOperation.ObservableBasedSingleChunkCreator<T,C> - 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 Closing>>) - 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
 
Closing - Interface in rx.util
 
Closings - Class in rx.util
 
combineLatest(Observable<? extends T1>, Observable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.Observable
Combines the 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 T1>, Observable<? extends T2>, Observable<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.Observable
 
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
 
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
 
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
 
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
 
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
 
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
 
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
 
CompositeException - Exception in rx.util
Exception that is a composite of 1 or more other exceptions.
CompositeException(String, Collection<Throwable>) - Constructor for exception rx.util.CompositeException
 
CompositeException(Collection<Throwable>) - Constructor for exception rx.util.CompositeException
 
CompositeSubscription - Class in rx.subscriptions
Subscription that represents a group of Subscriptions that are unsubscribed together.
CompositeSubscription(List<Subscription>) - Constructor for class rx.subscriptions.CompositeSubscription
 
CompositeSubscription(Subscription...) - Constructor for class rx.subscriptions.CompositeSubscription
 
concat(Observable<? extends T>...) - Static method in class rx.Observable
Returns an Observable that emits the items emitted by two or more Observables, one after the other.
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(List<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationConcat
 
concat(Observable<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationConcat
 
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 Observers.
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.OnSubscribeFunc<T>) - Constructor for class rx.observables.ConnectableObservable
 
contents - Variable in class rx.operators.ChunkedOperation.Chunk
 
create(Observable.OnSubscribeFunc<T>) - Static method in class rx.Observable
Creates an Observable that will execute the given function when an Observer subscribes to it.
create() - Static method in class rx.subjects.AsyncSubject
Create a new AsyncSubject
create() - Static method in class rx.subjects.PublishSubject
 
create() - Static method in class rx.subjects.ReplaySubject
 
create(Action0) - Static method in class rx.subscriptions.Subscriptions
A Subscription which invokes the given Action0 when unsubscribed.
create(Future<?>) - Static method in class rx.subscriptions.Subscriptions
A Subscription that wraps a Future and cancels it when unsubscribed.
create(Subscription...) - Static method in class rx.subscriptions.Subscriptions
A Subscription that groups multiple Subscriptions together and unsubscribes from all of them together.
create() - Static method in class rx.util.Closings
 
create() - Static method in class rx.util.Openings
 
create(int, int) - Static method in class rx.util.Range
 
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
 
createWithCount(int, int) - Static method in class rx.util.Range
 
createWithDefaultValue(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.
createWithStep(int, int, int) - Static method in class rx.util.Range
 
currentThread() - Static method in class rx.concurrency.Schedulers
Scheduler that queues work on the current thread to be executed after the current work completes.
CurrentThreadScheduler - Class in rx.concurrency
Schedules work on the current thread but does not execute immediately.

D

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
 
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.

E

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
 
empty() - Static method in class rx.Observable
Returns an Observable that emits no data to the Observer and immediately invokes its onCompleted method.
empty() - Static method in class rx.subscriptions.Subscriptions
A Subscription that does nothing.
equals(Object) - Method in class rx.Notification
 
equals(Object) - Method in class rx.util.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
Exceptions - Class in rx.util
 
executor(Executor) - Static method in class rx.concurrency.Schedulers
Scheduler that queues work on an Executor.
executor(ScheduledExecutorService) - Static method in class rx.concurrency.Schedulers
Scheduler that queues work on an ScheduledExecutorService.
ExecutorScheduler - Class in rx.concurrency
A Scheduler implementation that uses an Executor or ScheduledExecutorService implementation.
ExecutorScheduler(Executor) - Constructor for class rx.concurrency.ExecutorScheduler
 
ExecutorScheduler(ScheduledExecutorService) - Constructor for class rx.concurrency.ExecutorScheduler
 

F

filter(Func1<? super T, Boolean>) - Method in class rx.Observable
filter(Observable<? extends T>, Func1<? super T, Boolean>) - Static method in class rx.operators.OperationFilter
 
finallyDo(Action0) - Method in class rx.Observable
Registers an Action0 to be called when this Observable invokes 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).
flatMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Creates a new Observable by 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.
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(Iterable<? extends T>) - Static method in class rx.Observable
Converts an Iterable sequence into an Observable.
from(T...) - Static method in class rx.Observable
Converts an Array into an Observable.
from(Future<? extends T>) - Static method in class rx.Observable
Converts a Future into an Observable.
from(Future<? extends T>, Scheduler) - 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 timeout.
from(Observable<? extends T>) - Static method in class rx.observables.BlockingObservable
Convert an Observable into a BlockingObservable.
fromAction(Action0) - Static method in class rx.util.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.util.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.util.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.util.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
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
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
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
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
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
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
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
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
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
Convert a function to FuncN to allow heterogeneous handling of functions with different arities.
Func0<R> - Interface in rx.util.functions
 
Func1<T1,R> - Interface in rx.util.functions
 
Func2<T1,T2,R> - Interface in rx.util.functions
 
Func3<T1,T2,T3,R> - Interface in rx.util.functions
 
Func4<T1,T2,T3,T4,R> - Interface in rx.util.functions
 
Func5<T1,T2,T3,T4,T5,R> - Interface in rx.util.functions
 
Func6<T1,T2,T3,T4,T5,T6,R> - Interface in rx.util.functions
 
Func7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in rx.util.functions
 
Func8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in rx.util.functions
 
Func9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in rx.util.functions
 
FuncN<R> - Interface in rx.util.functions
 
Function - Interface in rx.util.functions
All Func and Action interfaces extend from this.
Functions - Class in rx.util.functions
 
Functions() - Constructor for class rx.util.functions.Functions
 

G

getChunk() - Method in class rx.operators.ChunkedOperation.Chunks
 
getContents() - Method in class rx.operators.ChunkedOperation.Chunk
 
getContents() - Method in class rx.operators.OperationBuffer.Buffer
 
getContents() - Method in class rx.operators.OperationWindow.Window
 
getErrorHandler() - Method in class rx.plugins.RxJavaPlugins
Retrieve instance of RxJavaErrorHandler to use based on order of precedence as defined in RxJavaPlugins class header.
getExceptions() - Method in exception rx.util.CompositeException
 
getInstance() - Static method in class rx.concurrency.CurrentThreadScheduler
 
getInstance() - Static method in class rx.concurrency.ImmediateScheduler
 
getInstance() - Static method in class rx.concurrency.NewThreadScheduler
 
getInstance() - Static method in class rx.plugins.RxJavaPlugins
 
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
getMessage() - Method in exception rx.util.CompositeException
 
getObservableExecutionHook() - Method in class rx.plugins.RxJavaPlugins
Retrieve instance of RxJavaObservableExecutionHook to use based on order of precedence as defined in RxJavaPlugins class header.
getThrowable() - Method in class rx.Notification
Retrieves the exception associated with an onError notification.
getTimestampMillis() - Method in class rx.util.Timestamped
Returns time timestamp, in milliseconds.
getValue() - Method in class rx.Notification
Retrieves the data associated with an onNext notification.
getValue() - Method in class rx.util.Timestamped
Returns the value.
groupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>) - Method in class rx.Observable
Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as GroupedObservables, one GroupedObservable per group.
groupBy(Func1<? super T, ? extends K>) - Method in class rx.Observable
Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as GroupedObservables, one GroupedObservable per group.
groupBy(Observable<? extends T>, Func1<? super T, ? extends K>, Func1<? super T, ? extends R>) - Static method in class rx.operators.OperationGroupBy
 
groupBy(Observable<? extends T>, Func1<? super T, ? extends K>) - Static method in class rx.operators.OperationGroupBy
 
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.OnSubscribeFunc<T>) - Constructor for class rx.observables.GroupedObservable
 

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.util.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.util.functions.Functions
 
immediate() - Static method in class rx.concurrency.Schedulers
Scheduler that executes work immediately on the current thread.
ImmediateScheduler - Class in rx.concurrency
Executes work immediately on the current thread.
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.
isOnCompleted() - Method in class rx.Notification
 
isOnError() - Method in class rx.Notification
 
isOnNext() - Method in class rx.Notification
 
isUnsubscribed() - Method in class rx.operators.SafeObservableSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.BooleanSubscription
 
isUnsubscribed() - Method in class rx.subscriptions.CompositeSubscription
 
iterator() - Method in class rx.util.Range
 

J

just(T) - Static method in class rx.Observable
Returns an Observable that emits a single item and then completes.

L

last() - Method in class rx.observables.BlockingObservable
Returns the last item emitted by a specified Observable.
last(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
Returns the last item emitted by a specified Observable that matches a predicate.
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.

M

map(Func1<? super T, ? extends R>) - Method in class rx.Observable
Returns an Observable that applies the given function to each item emitted by an Observable and emits the result.
map(Observable<? extends T>, Func1<? super T, ? extends R>) - Static method in class rx.operators.OperationMap
Accepts a sequence and a transformation function.
mapMany(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
Creates a new Observable by 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.
mapMany(Observable<? extends T>, Func1<? super T, ? extends Observable<? extends R>>) - Static method in class rx.operators.OperationMap
Accepts a sequence of observable sequences and a transformation function.
materialize() - Method in class rx.Observable
Turns all of the notifications from a source Observable into onNext emissions, and marks them with their original notification 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.
merge(List<? extends Observable<? extends T>>) - Static method in class rx.Observable
Flattens a list of Observables into one Observable, without any transformation.
merge(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Flattens a sequence of Observables emitted by an Observable into one Observable, without any transformation.
merge(Observable<? extends T>...) - Static method in class rx.Observable
Flattens a series of Observables into one Observable, without any transformation.
merge(Observable<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationMerge
Flattens the observable sequences from the list of Observables into one observable sequence without any transformation.
merge(Observable<? extends T>...) - Static method in class rx.operators.OperationMerge
 
merge(List<? extends Observable<? extends T>>) - Static method in class rx.operators.OperationMerge
 
mergeDelayError(List<? extends Observable<? extends T>>) - Static method in class rx.Observable
This behaves like Observable.merge(java.util.List) 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.
mergeDelayError(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
This behaves like Observable.merge(Observable) 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.
mergeDelayError(Observable<? extends T>...) - Static method in class rx.Observable
This behaves like Observable.merge(Observable...) 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.
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
 
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(Subject<T, 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<T, R>) - Static method in class rx.operators.OperationMulticast
 

N

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.concurrency.Schedulers
Scheduler that creates a new Thread for each unit of work.
NewThreadScheduler - Class in rx.concurrency
Schedules work on a new thread.
NewThreadScheduler() - Constructor for class rx.concurrency.NewThreadScheduler
 
next() - Method in class rx.observables.BlockingObservable
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
next(Observable<? extends T>) - Static method in class rx.operators.OperationNext
 
Notification<T> - Class in rx
An object representing a notification sent to an Observable.
Notification(T) - Constructor for class rx.Notification
A constructor used to represent an onNext notification.
Notification(Throwable) - Constructor for class rx.Notification
A constructor used to represent an onError notification.
Notification() - Constructor for class rx.Notification
A constructor used to represent an onCompleted notification.
Notification.Kind - Enum in rx
 
now() - Method in class rx.concurrency.TestScheduler
 
now() - Method in class rx.Scheduler
Returns the scheduler's notion of current absolute time in milliseconds.

O

Observable<T> - Class in rx
The Observable interface that implements the Reactive Pattern.
Observable(Observable.OnSubscribeFunc<T>) - Constructor for class rx.Observable
Observable with Function to execute when subscribed to.
Observable.OnSubscribeFunc<T> - Interface in rx
Function interface for work to be performed when an Observable is subscribed to via Observable.subscribe(Observer)
observeOn(Scheduler) - Method in class rx.Observable
Asynchronously notify Observers on the specified Scheduler.
observeOn(Observable<? extends T>, Scheduler) - Static method in class rx.operators.OperationObserveOn
 
Observer<T> - Interface in rx
Provides a mechanism for receiving push-based notifications.
onCompleted() - Method in interface rx.Observer
Notifies the Observer that the Observable has finished sending push-based notifications.
onCompleted() - Method in class rx.operators.ChunkedOperation.ChunkObserver
 
onCompleted() - Method in class rx.operators.SafeObserver
 
onCompleted() - Method in class rx.operators.SynchronizedObserver
 
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
 
onError(Throwable) - Method in interface rx.Observer
Notifies the Observer that the Observable has experienced an error condition.
onError(Throwable) - Method in class rx.operators.ChunkedOperation.ChunkObserver
 
onError(Throwable) - Method in class rx.operators.SafeObserver
 
onError(Throwable) - Method in class rx.operators.SynchronizedObserver
 
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
 
OnErrorNotImplementedException - Exception in rx.util
Used for re-throwing Observer.onError(Throwable) when an implementation doesn't exist.
OnErrorNotImplementedException(String, Throwable) - Constructor for exception rx.util.OnErrorNotImplementedException
 
OnErrorNotImplementedException(Throwable) - Constructor for exception rx.util.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.
onErrorResumeNextViaFunction(Observable<? extends T>, Func1<Throwable, ? extends Observable<? extends T>>) - Static method in class rx.operators.OperationOnErrorResumeNextViaFunction
 
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
 
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 error of type Exception.
onExceptionResumeNextViaObservable(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.operators.OperationOnExceptionResumeNextViaObservable
 
onNext(T) - Method in interface rx.Observer
Provides the Observer with new data.
onNext(T) - Method in class rx.operators.ChunkedOperation.ChunkObserver
 
onNext(T) - Method in class rx.operators.SafeObserver
 
onNext(T) - Method in class rx.operators.SynchronizedObserver
 
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
 
onSubscribe(Observer<? super T>) - Method in interface rx.Observable.OnSubscribeFunc
 
onSubscribeError(Observable<? extends T>, Throwable) - Method in class rx.plugins.RxJavaObservableExecutionHook
Invoked after failed execution of Observable.subscribe(Observer) with thrown Throwable.
onSubscribeReturn(Observable<? extends T>, Subscription) - Method in class rx.plugins.RxJavaObservableExecutionHook
Invoked after successful execution of Observable.subscribe(rx.Observer) with returned Subscription.
onSubscribeStart(Observable<? extends T>, Observable.OnSubscribeFunc<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
Invoked before Observable.subscribe(rx.Observer) 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
 
Opening - Interface in rx.util
 
Openings - Class in rx.util
 
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
 
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
 
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
 
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
 
OperationFilter<T> - Class in rx.operators
Filters an Observable by discarding any items it emits that do not meet some test.
OperationFilter() - Constructor for class rx.operators.OperationFilter
 
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
 
OperationGroupBy - 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.
OperationGroupBy() - Constructor for class rx.operators.OperationGroupBy
 
OperationInterval - Class in rx.operators
Returns an observable sequence that produces a value after each period.
OperationInterval() - Constructor for class rx.operators.OperationInterval
 
OperationMap - 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.
OperationMap() - Constructor for class rx.operators.OperationMap
 
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
 
OperationMerge - Class in rx.operators
Flattens a list of Observables into one Observable sequence, without any transformation.
OperationMerge() - Constructor for class rx.operators.OperationMerge
 
OperationMergeDelayError - Class in rx.operators
This behaves like OperationMerge 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
 
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
 
OperationObserveOn - Class in rx.operators
Asynchronously notify Observers on the specified Scheduler.
OperationObserveOn() - Constructor for class rx.operators.OperationObserveOn
 
OperationOnErrorResumeNextViaFunction<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.
OperationOnErrorResumeNextViaFunction() - Constructor for class rx.operators.OperationOnErrorResumeNextViaFunction
 
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
 
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
 
OperationScan - 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.
OperationScan() - Constructor for class rx.operators.OperationScan
 
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
 
OperationSubscribeOn - Class in rx.operators
Asynchronously subscribes and unsubscribes Observers on the specified Scheduler.
OperationSubscribeOn() - Constructor for class rx.operators.OperationSubscribeOn
 
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
 
OperationSynchronize<T> - Class in rx.operators
Wraps an Observable in another Observable that ensures that the resulting Observable is chronologically well-behaved.
OperationSynchronize() - Constructor for class rx.operators.OperationSynchronize
 
OperationTake - Class in rx.operators
Returns an Observable that emits the first num items emitted by the source Observable.
OperationTake() - Constructor for class rx.operators.OperationTake
 
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
 
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
 
OperationTimestamp - Class in rx.operators
Wraps each item emitted by a source Observable in a Timestamped object.
OperationTimestamp() - Constructor for class rx.operators.OperationTimestamp
 
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
 
OperationToObservableFuture - Class in rx.operators
Converts a Future into an Observable.
OperationToObservableFuture() - Constructor for class rx.operators.OperationToObservableFuture
 
OperationToObservableIterable<T> - Class in rx.operators
Converts an Iterable sequence into an Observable.
OperationToObservableIterable() - Constructor for class rx.operators.OperationToObservableIterable
 
OperationToObservableList<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.
OperationToObservableList() - Constructor for class rx.operators.OperationToObservableList
 
OperationToObservableSortedList<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).
OperationToObservableSortedList() - Constructor for class rx.operators.OperationToObservableSortedList
 
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
 
OperationZip - 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.
OperationZip() - Constructor for class rx.operators.OperationZip
 

P

propagate(Throwable) - Static method in class rx.util.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.
PublishSubject<T> - Class in rx.subjects
Subject that, once and Observer has subscribed, publishes all subsequent events to the subscriber.
PublishSubject(Observable.OnSubscribeFunc<T>, ConcurrentHashMap<Subscription, Observer<? super T>>, AtomicReference<Notification<? extends 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
 

R

range(int, int) - Static method in class rx.Observable
Generates an Observable that emits a sequence of integers within a specified range.
Range - Class in rx.util
 
reduce(Func2<? super T, ? super T, ? extends 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<? super R, ? super T, ? extends 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, 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.
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.
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.
ReplaySubject<T> - Class in rx.subjects
Subject that retains all events and will replay them to an Observer that subscribes.
rx - package rx
Rx Observables
rx.concurrency - package rx.concurrency
Rx Schedulers
rx.observables - package rx.observables
 
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.subjects - package rx.subjects
 
rx.subscriptions - package rx.subscriptions
 
rx.util - package rx.util
 
rx.util.functions - package rx.util.functions
 
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
Thread-safe wrapper around Observable Subscription that ensures unsubscribe can be called only once.
SafeObservableSubscription() - Constructor for class rx.operators.SafeObservableSubscription
 
SafeObservableSubscription(Subscription) - Constructor for class rx.operators.SafeObservableSubscription
 
SafeObserver<T> - Class in rx.operators
Wrapper around Observer to ensure compliance with Rx contract.
SafeObserver(SafeObservableSubscription, Observer<? super T>) - Constructor for class rx.operators.SafeObserver
 
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<? 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<? super T, ? super T, ? extends 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 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.
scan(R, Func2<? super R, ? super T, ? extends 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, 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.
scan(Observable<? extends T>, R, Func2<? super R, ? super T, ? extends R>) - Static method in class rx.operators.OperationScan
Applies an accumulator function over an observable sequence and returns each intermediate result with the specified source and accumulator.
scan(Observable<? extends T>, Func2<? super T, ? super T, ? extends T>) - Static method in class rx.operators.OperationScan
Applies an accumulator function over an observable sequence and returns each intermediate result with the specified source and accumulator.
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>) - Method in class rx.concurrency.CurrentThreadScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, long, TimeUnit) - Method in class rx.concurrency.CurrentThreadScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, long, TimeUnit) - Method in class rx.concurrency.ExecutorScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>) - Method in class rx.concurrency.ExecutorScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>) - Method in class rx.concurrency.ImmediateScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, long, TimeUnit) - Method in class rx.concurrency.ImmediateScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>) - Method in class rx.concurrency.NewThreadScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, long, TimeUnit) - Method in class rx.concurrency.NewThreadScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>) - Method in class rx.concurrency.TestScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, long, TimeUnit) - Method in class rx.concurrency.TestScheduler
 
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>) - Method in class rx.Scheduler
Schedules a cancelable action to be executed.
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, long, TimeUnit) - Method in class rx.Scheduler
Schedules a cancelable action to be executed in delayTime.
schedule(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, Date) - Method in class rx.Scheduler
Schedules a cancelable action to be executed at dueTime.
schedule(Action0) - Method in class rx.Scheduler
Schedules an action to be executed.
schedule(Action0, long, TimeUnit) - Method in class rx.Scheduler
Schedules an action to be executed in delayTime.
schedulePeriodically(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, long, long, TimeUnit) - Method in class rx.concurrency.ExecutorScheduler
 
schedulePeriodically(T, Func2<? super Scheduler, ? super T, ? extends Subscription>, long, long, TimeUnit) - Method in class rx.Scheduler
Schedules a cancelable action to be executed periodically.
schedulePeriodically(Action0, long, long, TimeUnit) - Method in class rx.Scheduler
Schedules an action to be executed periodically.
Scheduler - Class in rx
Represents an object that schedules units of work.
Scheduler() - Constructor for class rx.Scheduler
 
Schedulers - Class in rx.concurrency
Static factory methods for creating Schedulers.
sequenceEqual(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
Returns an Observable that emits Boolean values that indicate whether the pairs of items emitted by two source Observables are equal.
sequenceEqual(Observable<? extends T>, Observable<? extends T>, Func2<? super T, ? super T, Boolean>) - Static method in class rx.Observable
Returns an Observable that emits Boolean values that indicate whether the pairs of items emitted by two source Observables are equal based on the results of a specified equality function.
single() - Method in class rx.observables.BlockingObservable
If the Observable completes after emitting a single item, return that item, otherwise throw an exception.
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 exception.
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 exception; 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 exception; if it emits no items, return a default value.
size() - Method in class rx.operators.ChunkedOperation.Chunk
 
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(Observable<? extends T>, int) - Static method in class rx.operators.OperationSkip
Skips a specified number of contiguous values from the start of a Observable sequence and then returns the remaining values.
startWith(T...) - Method in class rx.Observable
Emit a specified set of items before beginning to emit items from the source Observable.
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.OnSubscribeFunc<R>) - Constructor for class rx.subjects.Subject
 
subscribe(Observer<? 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(Observer<? 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(Action1<? super T>) - Method in class rx.Observable
 
subscribe(Action1<? super T>, Scheduler) - Method in class rx.Observable
 
subscribe(Action1<? super T>, Action1<Throwable>) - Method in class rx.Observable
 
subscribe(Action1<? super T>, Action1<Throwable>, Scheduler) - Method in class rx.Observable
 
subscribe(Action1<? super T>, Action1<Throwable>, Action0) - Method in class rx.Observable
 
subscribe(Action1<? super T>, Action1<Throwable>, Action0, Scheduler) - Method in class rx.Observable
 
subscribeOn(Scheduler) - Method in class rx.Observable
Asynchronously subscribes and unsubscribes Observers on the specified Scheduler.
subscribeOn(Observable<? extends T>, Scheduler) - Static method in class rx.operators.OperationSubscribeOn
 
Subscription - Interface in rx
Subscription returns from Observable.subscribe(Observer) 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
 
switchDo(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Deprecated. Being renamed to 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.
switchOnNext(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
Given an Observable that emits Observables, creates a single Observable that emits the items emitted by the most recently published of those Observables.
synchronize(Observable<? extends T>) - Static method in class rx.Observable
Accepts an Observable and wraps it in another Observable that ensures that the resulting Observable is chronologically well-behaved.
synchronize(Observable<? extends T>) - Static method in class rx.operators.OperationSynchronize
Accepts an observable and wraps it in another observable which ensures that the resulting observable is well-behaved.
SynchronizedObserver<T> - Class in rx.operators
A thread-safe Observer for transitioning states in operators.
SynchronizedObserver(Observer<? super T>, SafeObservableSubscription) - Constructor for class rx.operators.SynchronizedObserver
 

T

take(int) - Method in class rx.Observable
Returns an Observable that emits only the first num items emitted by the source Observable.
take(Observable<? extends T>, int) - Static method in class rx.operators.OperationTake
Returns a specified number of contiguous values from the start of an observable sequence.
takeLast(int) - Method in class rx.Observable
Returns an Observable that emits only the last count items emitted by the source Observable.
takeLast(Observable<? extends T>, int) - Static method in class rx.operators.OperationTakeLast
 
takeUntil(Observable<? extends E>) - Method in class rx.Observable
Returns an Observable that emits the items from the source Observable only until the other 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 a specified condition is true.
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 can operate on both the item and its index relative to the complete sequence.
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.
testExceptionWithMoreThanOneElement() - Method in class rx.operators.OperationToFuture
 
TestScheduler - Class in rx.concurrency
 
TestScheduler() - Constructor for class rx.concurrency.TestScheduler
 
testToFuture() - Method in class rx.operators.OperationToFuture
 
testToFutureList() - Method in class rx.operators.OperationToFuture
 
testToFutureWithException() - Method in class rx.operators.OperationToFuture
 
testToIterator() - Method in class rx.operators.OperationToIterator
 
testToIteratorWithException() - Method in class rx.operators.OperationToIterator
 
threadPoolForComputation() - Static method in class rx.concurrency.Schedulers
Scheduler intended for computational work.
threadPoolForIO() - Static method in class rx.concurrency.Schedulers
Scheduler intended for IO-bound work.
timestamp() - Method in class rx.Observable
Wraps each item emitted by a source Observable in a Timestamped object.
timestamp(Observable<? extends T>) - Static method in class rx.operators.OperationTimestamp
Accepts a sequence and adds timestamps to each item in it.
Timestamped<T> - Class in rx.util
Composite class that takes a value and a timestamp and wraps them.
Timestamped(long, T) - Constructor for class rx.util.Timestamped
 
toBlockingObservable() - Method in class rx.Observable
Converts an Observable into a BlockingObservable (an Observable with blocking operators).
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.
toObservableFuture(Future<? extends T>) - Static method in class rx.operators.OperationToObservableFuture
 
toObservableFuture(Future<? extends T>, long, TimeUnit) - Static method in class rx.operators.OperationToObservableFuture
 
toObservableIterable(Iterable<? extends T>) - Static method in class rx.operators.OperationToObservableIterable
 
toObservableList(Observable<? extends T>) - Static method in class rx.operators.OperationToObservableList
 
toSortedList() - Method in class rx.Observable
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).
toSortedList(Func2<? super T, ? super T, Integer>) - Method in class rx.Observable
Return an Observable that emits the items emitted by the source Observable, in a sorted order based on a specified comparison function
toSortedList(Observable<? extends T>) - Static method in class rx.operators.OperationToObservableSortedList
Sort T objects by their natural order (object must implement Comparable).
toSortedList(Observable<? extends T>, Func2<? super T, ? super T, Integer>) - Static method in class rx.operators.OperationToObservableSortedList
Sort T objects using the defined sort function.
toString() - Method in class rx.Notification
 
toString() - Method in class rx.util.Range
 
toString() - Method in class rx.util.Timestamped
 
triggerActions() - Method in class rx.concurrency.TestScheduler
 

U

unsubscribe() - Method in class rx.operators.SafeObservableSubscription
 
unsubscribe() - Method in interface rx.Subscription
Stop receiving notifications on the Observer that was registered when this Subscription was received.
unsubscribe() - Method in class rx.subscriptions.BooleanSubscription
 
unsubscribe() - Method in class rx.subscriptions.CompositeSubscription
 

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

where(Func1<? super T, Boolean>) - Method in class rx.Observable
window(Observable<? extends T>, Func0<? extends Observable<? extends Closing>>) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, Observable<? extends Opening>, Func1<Opening, ? extends Observable<? extends Closing>>) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, int) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, int, int) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, long, TimeUnit) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, long, TimeUnit, Scheduler) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, long, TimeUnit, int) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, long, TimeUnit, int, Scheduler) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, long, long, TimeUnit) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, long, long, TimeUnit, Scheduler) - Method in class rx.Observable
Creates an Observable which produces windows of collected values.
window(Observable<? extends T>, Func0<? extends Observable<? extends Closing>>) - Static method in class rx.operators.OperationWindow
This method creates a Func1 object which represents the window operation.
window(Observable<? extends T>, Observable<? extends Opening>, Func1<Opening, ? extends Observable<? extends Closing>>) - 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.
windowMaker() - Static method in class rx.operators.OperationWindow
 
wrap(Subscription) - Method in class rx.operators.SafeObservableSubscription
Wraps the actual subscription once it exists (if it wasn't available when constructed)

Z

zip(Observable<? extends T1>, Observable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.Observable
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 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>, 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 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>, 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 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>, 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 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>, 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 four items emitted, in sequence, by four 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 four items emitted, in sequence, by four other Observables.
zip(Collection<? 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 four items emitted, in sequence, by four other Observables.
zip(Observable<? extends T1>, Observable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.operators.OperationZip
 
zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.operators.OperationZip
 
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.operators.OperationZip
 
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.operators.OperationZip
 
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.operators.OperationZip
 
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.operators.OperationZip
 
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.operators.OperationZip
 
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.operators.OperationZip
 
zip(Collection<? extends Observable<?>>, FuncN<? extends R>) - Static method in class rx.operators.OperationZip
 

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