RxJava


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

A

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
 
alwaysTrue() - Static method in class rx.util.functions.Functions
 
AtomicObservableSubscription - Class in rx.util
Thread-safe wrapper around Observable Subscription that ensures unsubscribe can be called only once.
AtomicObservableSubscription() - Constructor for class rx.util.AtomicObservableSubscription
 
AtomicObservableSubscription(Subscription) - Constructor for class rx.util.AtomicObservableSubscription
 
AtomicObserver<T> - Class in rx.util
Wrapper around Observer to ensure compliance with Rx contract.
AtomicObserver(AtomicObservableSubscription, Observer<T>) - Constructor for class rx.util.AtomicObserver
 

B

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
 

C

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
 
call(Object, Object[]) - Method in interface rx.util.functions.FunctionLanguageAdaptor
Invoke the function and return the results.
combineLatest(Observable<T0>, Observable<T1>, Func2<T0, T1, R>) - Static method in class rx.operators.OperationCombineLatest
 
combineLatest(Observable<T0>, Observable<T1>, Observable<T2>, Func3<T0, T1, T2, R>) - Static method in class rx.operators.OperationCombineLatest
 
combineLatest(Observable<T0>, Observable<T1>, Observable<T2>, Observable<T3>, Func4<T0, T1, T2, T3, 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<Exception>) - Constructor for exception rx.util.CompositeException
 
CompositeException(Collection<Exception>) - Constructor for exception rx.util.CompositeException
 
concat(Observable<T>...) - Static method in class rx.Observable
Combines the objects emitted by two or more Observables, and emits the result as a single Observable, by using the concat method.
concat(Observable<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<Observable<T>>) - Static method in class rx.operators.OperationConcat
 
concat(Observable<Observable<T>>) - Static method in class rx.operators.OperationConcat
 
create(Func1<Observer<T>, Subscription>) - Static method in class rx.Observable
Creates an Observable that will execute the given function when a Observer subscribes to it.
create(Object) - Static method in class rx.Observable
Creates an Observable that will execute the given function when a Observer subscribes to it.
create() - Static method in class rx.subjects.Subject
 
create(Action0) - Static method in class rx.subscriptions.Subscriptions
A Subscription implemented via a Func
create(Object) - Static method in class rx.subscriptions.Subscriptions
A Subscription implemented via an anonymous function (such as closures from other languages).
create(int, int) - Static method in class rx.util.Range
 
createWithCount(int, int) - Static method in class rx.util.Range
 
createWithStep(int, int, int) - Static method in class rx.util.Range
 

D

defer(Func0<Observable<T>>) - Static method in class rx.Observable
Returns an observable sequence that invokes the observable factory whenever a new observer subscribes.
defer(Object) - Static method in class rx.Observable
Returns an observable sequence that invokes the observable factory whenever a new observer subscribes.
defer(Func0<Observable<T>>) - Static method in class rx.operators.OperationDefer
 
dematerialize(Observable<Notification<T>>) - Static method in class rx.Observable
Dematerializes the explicit notification values of an observable sequence as implicit notifications.
dematerialize() - Method in class rx.Observable
Dematerializes the explicit notification values of an observable sequence as implicit notifications.
dematerialize(Observable<Notification<T>>) - Static method in class rx.operators.OperationDematerialize
Dematerializes the explicit notification values of an observable sequence as implicit notifications.

E

empty() - Static method in class rx.Observable
Returns an Observable that returns 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
 
error(Exception) - Static method in class rx.Observable
Returns an Observable that calls onError when an Observer subscribes to it.
Exceptions - Class in rx.util
 

F

filter(Observable<T>, Func1<T, Boolean>) - Static method in class rx.Observable
Filters an Observable by discarding any of its emissions that do not meet some test.
filter(Observable<T>, Object) - Static method in class rx.Observable
Filters an Observable by discarding any of its emissions that do not meet some test.
filter(Func1<T, Boolean>) - Method in class rx.Observable
Filters an Observable by discarding any of its emissions that do not meet some test.
filter(Object) - Method in class rx.Observable
Filters an Observable by discarding any of its emissions that do not meet some test.
filter(Observable<T>, Func1<T, Boolean>) - Static method in class rx.operators.OperationFilter
 
forEach(Action1<T>) - Method in class rx.Observable
Invokes an action for each element in the observable sequence, and blocks until the sequence is terminated.
forEach(Object) - Method in class rx.Observable
 
from(Iterable<T>) - Static method in class rx.Observable
Converts an Iterable sequence to an Observable sequence.
from(T...) - Static method in class rx.Observable
Converts an Array to an Observable sequence.
from(Object) - Static method in class rx.util.functions.Functions
Utility method for determining the type of closure/function and executing it.
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<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<T0, 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<T0, T1, 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<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<T0, 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<T0, T1, 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<T0, T1, T2, 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<T0, T1, T2, T3, 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<T0, T1, T2, T3, T4, 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<T0, T1, T2, T3, T4, T5, 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<T0, T1, T2, T3, T4, T5, T6, 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<T0, T1, T2, T3, T4, T5, T6, T7, 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<T0, T1, T2, T3, T4, T5, T6, T7, T8, 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.
FunctionLanguageAdaptor - Interface in rx.util.functions
 
Functions - Class in rx.util.functions
Allows execution of functions from multiple different languages.
Functions() - Constructor for class rx.util.functions.Functions
 

G

getErrorHandler() - Method in class rx.plugins.RxJavaPlugins
Retrieve instance of RxJavaErrorHandler to use based on order of precedence as defined in RxJavaPlugins class header.
getException() - Method in class rx.Notification
Retrieves the exception associated with an onError notification.
getExceptions() - Method in exception rx.util.CompositeException
 
getFunctionClass() - Method in interface rx.util.functions.FunctionLanguageAdaptor
The Class of the Function that this adaptor serves.
getInstance() - Static method in class rx.plugins.RxJavaPlugins
 
getIterator(Observable<T>) - Static method in class rx.Observable
Returns an iterator that iterates all values of the observable.
getIterator() - Method in class rx.Observable
Returns an iterator that iterates all values of the observable.
getKey() - Method in class rx.observables.GroupedObservable
 
getKind() - Method in class rx.Notification
The kind of notification: OnNext, OnError, OnCompleted
getMessage() - Method in exception rx.util.CompositeException
 
getRegisteredLanguageAdaptors() - Static method in class rx.util.functions.Functions
 
getValue() - Method in class rx.Notification
Retrieves the data associated with an onNext notification.
groupBy(Observable<T>, Func1<T, K>, Func1<T, R>) - Static method in class rx.Observable
Groups the elements of an observable and selects the resulting elements by using a specified function.
groupBy(Observable<T>, Func1<T, K>) - Static method in class rx.Observable
Groups the elements of an observable according to a specified key selector function and
groupBy(Func1<T, K>, Func1<T, R>) - Method in class rx.Observable
Groups the elements of an observable and selects the resulting elements by using a specified function.
groupBy(Func1<T, K>) - Method in class rx.Observable
Groups the elements of an observable according to a specified key selector function and
groupBy(Observable<T>, Func1<T, K>, Func1<T, R>) - Static method in class rx.operators.OperatorGroupBy
 
groupBy(Observable<T>, Func1<T, K>) - Static method in class rx.operators.OperatorGroupBy
 
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, Func1<Observer<T>, Subscription>) - Constructor for class rx.observables.GroupedObservable
 

H

handleError(Exception) - Method in class rx.plugins.RxJavaErrorHandler
Receives all Exceptions from an Observable passed to Observer.onError(Exception).
hasException() - Method in class rx.Notification
Retrieves a value indicating whether this notification has an exception.
hashCode() - Method in class rx.Notification
 
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
 
isOnCompleted() - Method in class rx.Notification
 
isOnError() - Method in class rx.Notification
 
isOnNext() - Method in class rx.Notification
 
isUnsubscribed() - Method in class rx.subscriptions.BooleanSubscription
 
isUnsubscribed() - Method in class rx.util.AtomicObservableSubscription
 
iterator() - Method in class rx.util.Range
 

J

just(T) - Static method in class rx.Observable
Returns an Observable that notifies an Observer of a single value and then completes.

L

last(Observable<T>) - Static method in class rx.Observable
Returns the last element of an observable sequence with a specified source.
last(Observable<T>, Func1<T, Boolean>) - Static method in class rx.Observable
Returns the last element of an observable sequence that matches the predicate.
last(Observable<T>, Object) - Static method in class rx.Observable
Returns the last element of an observable sequence that matches the predicate.
last() - Method in class rx.Observable
Returns the last element of an observable sequence with a specified source.
last(Func1<T, Boolean>) - Method in class rx.Observable
Returns the last element of an observable sequence that matches the predicate.
last(Object) - Method in class rx.Observable
Returns the last element of an observable sequence that matches the predicate.
lastOrDefault(Observable<T>, T) - Static method in class rx.Observable
Returns the last element of an observable sequence, or a default value if no value is found.
lastOrDefault(Observable<T>, T, Func1<T, Boolean>) - Static method in class rx.Observable
Returns the last element of an observable sequence that matches the predicate, or a default value if no value is found.
lastOrDefault(Observable<T>, T, Object) - Static method in class rx.Observable
Returns the last element of an observable sequence that matches the predicate, or a default value if no value is found.
lastOrDefault(T) - Method in class rx.Observable
Returns the last element, or a default value if no value is found.
lastOrDefault(T, Func1<T, Boolean>) - Method in class rx.Observable
Returns the last element that matches the predicate, or a default value if no value is found.
lastOrDefault(T, Object) - Method in class rx.Observable
Returns the last element that matches the predicate, or a default value if no value is found.

M

map(Observable<T>, Func1<T, R>) - Static method in class rx.Observable
Applies a function of your choosing to every notification emitted by an Observable, and returns this transformation as a new Observable sequence.
map(Observable<T>, Object) - Static method in class rx.Observable
Applies a function of your choosing to every notification emitted by an Observable, and returns this transformation as a new Observable sequence.
map(Func1<T, R>) - Method in class rx.Observable
Applies a function of your choosing to every item emitted by an Observable, and returns this transformation as a new Observable sequence.
map(Object) - Method in class rx.Observable
Applies a function of your choosing to every item emitted by an Observable, and returns this transformation as a new Observable sequence.
map(Observable<T>, Func1<T, R>) - Static method in class rx.operators.OperationMap
Accepts a sequence and a transformation function.
mapMany(Observable<T>, Func1<T, Observable<R>>) - Static method in class rx.Observable
Creates a new Observable sequence by applying a function that you supply to each object in the original Observable sequence, where that function is itself an Observable that emits objects, and then merges the results of that function applied to every item emitted by the original Observable, emitting these merged results as its own sequence.
mapMany(Observable<T>, Object) - Static method in class rx.Observable
Creates a new Observable sequence by applying a function that you supply to each object in the original Observable sequence, where that function is itself an Observable that emits objects, and then merges the results of that function applied to every item emitted by the original Observable, emitting these merged results as its own sequence.
mapMany(Func1<T, Observable<R>>) - Method in class rx.Observable
Creates a new Observable sequence by applying a function that you supply to each item in the original Observable sequence, where that function is itself an Observable that emits items, and then merges the results of that function applied to every item emitted by the original Observable, emitting these merged results as its own sequence.
mapMany(Object) - Method in class rx.Observable
Creates a new Observable sequence by applying a function that you supply to each item in the original Observable sequence, where that function is itself an Observable that emits items, and then merges the results of that function applied to every item emitted by the original Observable, emitting these merged results as its own sequence.
mapMany(Observable<T>, Func1<T, Observable<R>>) - Static method in class rx.operators.OperationMap
Accepts a sequence of observable sequences and a transformation function.
materialize(Observable<T>) - Static method in class rx.Observable
Materializes the implicit notifications of an observable sequence as explicit notification values.
materialize() - Method in class rx.Observable
Materializes the implicit notifications of this observable sequence as explicit notification values.
materialize(Observable<T>) - Static method in class rx.operators.OperationMaterialize
Materializes the implicit notifications of an observable sequence as explicit notification values.
merge(List<Observable<T>>) - Static method in class rx.Observable
Flattens the Observable sequences from a list of Observables into one Observable sequence without any transformation.
merge(Observable<Observable<T>>) - Static method in class rx.Observable
Flattens the Observable sequences emitted by a sequence of Observables that are emitted by a Observable into one Observable sequence without any transformation.
merge(Observable<T>...) - Static method in class rx.Observable
Flattens the Observable sequences from a series of Observables into one Observable sequence without any transformation.
merge(Observable<Observable<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<T>...) - Static method in class rx.operators.OperationMerge
 
merge(List<Observable<T>>) - Static method in class rx.operators.OperationMerge
 
mergeDelayError(List<Observable<T>>) - Static method in class rx.Observable
Same functionality as merge except that errors received to onError will be held until all sequences have finished (onComplete/onError) before sending the error.
mergeDelayError(Observable<Observable<T>>) - Static method in class rx.Observable
Same functionality as merge except that errors received to onError will be held until all sequences have finished (onComplete/onError) before sending the error.
mergeDelayError(Observable<T>...) - Static method in class rx.Observable
Same functionality as merge except that errors received to onError will be held until all sequences have finished (onComplete/onError) before sending the error.
mergeDelayError(Observable<Observable<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<T>...) - Static method in class rx.operators.OperationMergeDelayError
 
mergeDelayError(List<Observable<T>>) - Static method in class rx.operators.OperationMergeDelayError
 
mostRecent(Observable<T>, T) - Static method in class rx.Observable
Samples the most recent value in an observable sequence.
mostRecent(T) - Method in class rx.Observable
Samples the most recent value in an observable sequence.
mostRecent(Observable<T>, T) - Static method in class rx.operators.OperationMostRecent
 

N

never() - Static method in class rx.Observable
Returns an Observable that never sends any information to an Observer.
next(Observable<T>) - Static method in class rx.Observable
Samples the next value (blocking without buffering) from in an observable sequence.
next() - Method in class rx.Observable
Samples the next value (blocking without buffering) from in an observable sequence.
next(Observable<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(Exception) - 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
 

O

Observable<T> - Class in rx
The Observable interface that implements the Reactive Pattern.
Observable() - Constructor for class rx.Observable
 
Observable(Func1<Observer<T>, Subscription>) - Constructor for class rx.Observable
Construct an Observable with Function to execute when subscribed to.
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.subjects.Subject
 
onCompleted() - Method in class rx.util.AtomicObserver
 
onCompleted() - Method in class rx.util.SynchronizedObserver
 
onError(Exception) - Method in interface rx.Observer
Notifies the Observer that the Observable has experienced an error condition.
onError(Exception) - Method in class rx.subjects.Subject
 
onError(Exception) - Method in class rx.util.AtomicObserver
 
onError(Exception) - Method in class rx.util.SynchronizedObserver
 
onErrorResumeNext(Observable<T>, Func1<Exception, Observable<T>>) - Static method in class rx.Observable
Instruct an Observable to pass control to another Observable (the return value of a function) rather than calling onError if it encounters an error.
onErrorResumeNext(Observable<T>, Object) - Static method in class rx.Observable
Instruct an Observable to pass control to another Observable (the return value of a function) rather than calling onError if it encounters an error.
onErrorResumeNext(Observable<T>, Observable<T>) - Static method in class rx.Observable
Instruct an Observable to pass control to another Observable rather than calling onError if it encounters an error.
onErrorResumeNext(Func1<Exception, Observable<T>>) - Method in class rx.Observable
Instruct an Observable to pass control to another Observable rather than calling onError if it encounters an error.
onErrorResumeNext(Object) - Method in class rx.Observable
Instruct an Observable to emit a particular item rather than calling onError if it encounters an error.
onErrorResumeNext(Observable<T>) - Method in class rx.Observable
Instruct an Observable to pass control to another Observable rather than calling onError if it encounters an error.
onErrorResumeNextViaFunction(Observable<T>, Func1<Exception, Observable<T>>) - Static method in class rx.operators.OperationOnErrorResumeNextViaFunction
 
onErrorResumeNextViaObservable(Observable<T>, Observable<T>) - Static method in class rx.operators.OperationOnErrorResumeNextViaObservable
 
onErrorReturn(Observable<T>, Func1<Exception, T>) - Static method in class rx.Observable
Instruct an Observable to emit a particular item to its Observer's onNext function rather than calling onError if it encounters an error.
onErrorReturn(Func1<Exception, T>) - Method in class rx.Observable
Instruct an Observable to emit a particular item rather than calling onError if it encounters an error.
onErrorReturn(Object) - Method in class rx.Observable
Instruct an Observable to emit a particular item rather than calling onError if it encounters an error.
onErrorReturn(Observable<T>, Func1<Exception, T>) - Static method in class rx.operators.OperationOnErrorReturn
 
onNext(T) - Method in interface rx.Observer
Provides the Observer with new data.
onNext(T) - Method in class rx.subjects.Subject
 
onNext(T) - Method in class rx.util.AtomicObserver
 
onNext(T) - Method in class rx.util.SynchronizedObserver
 
OperationCombineLatest - Class in rx.operators
 
OperationCombineLatest() - Constructor for class rx.operators.OperationCombineLatest
 
OperationConcat - Class in rx.operators
 
OperationConcat() - Constructor for class rx.operators.OperationConcat
 
OperationDefer - Class in rx.operators
 
OperationDefer() - Constructor for class rx.operators.OperationDefer
 
OperationDematerialize - Class in rx.operators
Dematerializes the explicit notification values of an observable sequence as implicit notifications.
OperationDematerialize() - Constructor for class rx.operators.OperationDematerialize
 
OperationFilter<T> - Class in rx.operators
 
OperationFilter() - Constructor for class rx.operators.OperationFilter
 
OperationMap - Class in rx.operators
 
OperationMap() - Constructor for class rx.operators.OperationMap
 
OperationMaterialize - Class in rx.operators
Materializes the implicit notifications of an observable sequence as explicit notification values.
OperationMaterialize() - Constructor for class rx.operators.OperationMaterialize
 
OperationMerge - Class in rx.operators
 
OperationMerge() - Constructor for class rx.operators.OperationMerge
 
OperationMergeDelayError - Class in rx.operators
Same functionality as OperationMerge except that onError events will be skipped so that all onNext calls are passed on until all sequences finish with onComplete or onError, and then the first onError received (if any) will be passed on.
OperationMergeDelayError() - Constructor for class rx.operators.OperationMergeDelayError
 
OperationMostRecent - Class in rx.operators
Samples the most recent value in an observable sequence.
OperationMostRecent() - Constructor for class rx.operators.OperationMostRecent
 
OperationNext - Class in rx.operators
Samples the next value (blocking without buffering) from in an observable sequence.
OperationNext() - Constructor for class rx.operators.OperationNext
 
OperationOnErrorResumeNextViaFunction<T> - Class in rx.operators
 
OperationOnErrorResumeNextViaFunction() - Constructor for class rx.operators.OperationOnErrorResumeNextViaFunction
 
OperationOnErrorResumeNextViaObservable<T> - Class in rx.operators
 
OperationOnErrorResumeNextViaObservable() - Constructor for class rx.operators.OperationOnErrorResumeNextViaObservable
 
OperationOnErrorReturn<T> - Class in rx.operators
When an onError occurs the resumeFunction will be executed and it's response passed to onNext instead of calling onError.
OperationOnErrorReturn() - Constructor for class rx.operators.OperationOnErrorReturn
 
OperationScan - Class in rx.operators
 
OperationScan() - Constructor for class rx.operators.OperationScan
 
OperationSkip - Class in rx.operators
Skips a specified number of contiguous values from the start of a Observable sequence and then returns the remaining values.
OperationSkip() - Constructor for class rx.operators.OperationSkip
 
OperationSynchronize<T> - Class in rx.operators
An observable that wraps an observable of the same type and then enforces the semantics expected of a well-behaved observable.
OperationSynchronize() - Constructor for class rx.operators.OperationSynchronize
 
OperationTake - Class in rx.operators
Returns a specified number of contiguous values from the start of an observable sequence.
OperationTake() - Constructor for class rx.operators.OperationTake
 
OperationTakeLast - Class in rx.operators
Returns a specified number of contiguous elements from the end of an observable sequence.
OperationTakeLast() - Constructor for class rx.operators.OperationTakeLast
 
OperationToObservableFuture - Class in rx.operators
 
OperationToObservableFuture() - Constructor for class rx.operators.OperationToObservableFuture
 
OperationToObservableIterable<T> - Class in rx.operators
Accepts an Iterable object and exposes it as an Observable.
OperationToObservableIterable() - Constructor for class rx.operators.OperationToObservableIterable
 
OperationToObservableList<T> - Class in rx.operators
 
OperationToObservableList() - Constructor for class rx.operators.OperationToObservableList
 
OperationToObservableSortedList<T> - Class in rx.operators
Similar to toList in that it converts a sequence into a List except that it accepts a Function that will provide an implementation of Comparator.
OperationToObservableSortedList() - Constructor for class rx.operators.OperationToObservableSortedList
 
OperationZip - Class in rx.operators
 
OperationZip() - Constructor for class rx.operators.OperationZip
 
OperatorGroupBy - Class in rx.operators
 
OperatorGroupBy() - Constructor for class rx.operators.OperatorGroupBy
 
OperatorTakeUntil - Class in rx.operators
 
OperatorTakeUntil() - Constructor for class rx.operators.OperatorTakeUntil
 
OperatorToIterator - Class in rx.operators
 
OperatorToIterator() - Constructor for class rx.operators.OperatorToIterator
 

P

propagate(Throwable) - Static method in class rx.util.Exceptions
 

R

range(int, int) - Static method in class rx.Observable
Generates an observable sequence of integral numbers within a specified range.
Range - Class in rx.util
 
reduce(Observable<T>, Func2<T, T, T>) - Static 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 output.
reduce(Observable<T>, Object) - Static 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 output.
reduce(Observable<T>, T, Func2<T, T, T>) - Static 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 output.
reduce(Observable<T>, T, Object) - Static 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 output.
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 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 output.
reduce(Object) - 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 output.
reduce(T, 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 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 output.
reduce(T, Object) - 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 output.
registerErrorHandler(RxJavaErrorHandler) - Method in class rx.plugins.RxJavaPlugins
Register a HystrixEventNotifier implementation as a global override of any injected or default implementations.
registerLanguageAdaptor(Class<?>[], FunctionLanguageAdaptor) - Static method in class rx.util.functions.Functions
 
removeLanguageAdaptor(Class<?>) - Static method in class rx.util.functions.Functions
 
rx - package rx
Rx Observables
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(Exception) behavior.
RxJavaErrorHandler() - Constructor for class rx.plugins.RxJavaErrorHandler
 
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

scan(Observable<T>, Func2<T, T, T>) - Static 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 as its own sequence.
scan(Observable<T>, Object) - Static 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 as its own sequence.
scan(Observable<T>, T, Func2<T, T, T>) - Static 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 as its own sequence.
scan(Observable<T>, T, Object) - Static 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 as its own sequence.
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 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(Object) - 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(T, 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 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(T, Object) - 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, then feeds the result of that function along with the third item into the same function, and so on, emitting the result of each of these iterations.
scan(Observable<T>, T, Func2<T, T, 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.
scan(Observable<T>, Func2<T, T, 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.
sequenceEqual(Observable<T>, Observable<T>) - Static method in class rx.Observable
Determines whether two sequences are equal by comparing the elements pairwise.
sequenceEqual(Observable<T>, Observable<T>, Func2<T, T, Boolean>) - Static method in class rx.Observable
Determines whether two sequences are equal by comparing the elements pairwise using a specified equality function.
sequenceEqual(Observable<T>, Observable<T>, Object) - Static method in class rx.Observable
Determines whether two sequences are equal by comparing the elements pairwise using a specified equality function.
single() - Method in class rx.Observable
Returns the only element of an observable sequence and throws an exception if there is not exactly one element in the observable sequence.
single(Func1<T, Boolean>) - Method in class rx.Observable
Returns the only element of an observable sequence that matches the predicate and throws an exception if there is not exactly one element in the observable sequence.
single(Object) - Method in class rx.Observable
Returns the only element of an observable sequence that matches the predicate and throws an exception if there is not exactly one element in the observable sequence.
single(Observable<T>) - Static method in class rx.Observable
Returns the only element of an observable sequence and throws an exception if there is not exactly one element in the observable sequence.
single(Observable<T>, Func1<T, Boolean>) - Static method in class rx.Observable
Returns the only element of an observable sequence that matches the predicate and throws an exception if there is not exactly one element in the observable sequence.
single(Observable<T>, Object) - Static method in class rx.Observable
Returns the only element of an observable sequence that matches the predicate and throws an exception if there is not exactly one element in the observable sequence.
singleOrDefault(T) - Method in class rx.Observable
Returns the only element of an observable sequence, or a default value if the observable sequence is empty.
singleOrDefault(T, Func1<T, Boolean>) - Method in class rx.Observable
Returns the only element of an observable sequence that matches the predicate, or a default value if no value is found.
singleOrDefault(T, Object) - Method in class rx.Observable
Returns the only element of an observable sequence that matches the predicate, or a default value if no value is found.
singleOrDefault(Observable<T>, T) - Static method in class rx.Observable
Returns the only element of an observable sequence, or a default value if the observable sequence is empty.
singleOrDefault(Observable<T>, T, Func1<T, Boolean>) - Static method in class rx.Observable
Returns the only element of an observable sequence that matches the predicate, or a default value if no value is found.
singleOrDefault(Observable<T>, T, Object) - Static method in class rx.Observable
Returns the only element of an observable sequence that matches the predicate, or a default value if no value is found.
skip(Observable<T>, int) - Static method in class rx.Observable
Returns an Observable that skips the first num items emitted by the source Observable.
skip(int) - Method in class rx.Observable
Returns an Observable that skips the first num items emitted by the source Observable.
skip(Observable<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
 
Subject<T> - Class in rx.subjects
 
Subject(Func1<Observer<T>, Subscription>, ConcurrentHashMap<Subscription, Observer<T>>) - Constructor for class rx.subjects.Subject
 
subscribe(Observer<T>) - Method in class rx.Observable
an Observer must call an Observable's subscribe method in order to register itself to receive push-based notifications from the Observable.
subscribe(Map<String, Object>) - Method in class rx.Observable
 
subscribe(Object) - Method in class rx.Observable
 
subscribe(Action1<T>) - Method in class rx.Observable
 
subscribe(Object, Object) - Method in class rx.Observable
 
subscribe(Action1<T>, Action1<Exception>) - Method in class rx.Observable
 
subscribe(Object, Object, Object) - Method in class rx.Observable
 
subscribe(Action1<T>, Action1<Exception>, Action0) - Method in class rx.Observable
 
Subscription - Interface in rx
Subscription returns from Observable.subscribe(Observer) to allow unsubscribing.
Subscriptions - Class in rx.subscriptions
 
Subscriptions() - Constructor for class rx.subscriptions.Subscriptions
 
synchronize(Observable<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<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.util
A thread-safe Observer for transitioning states in operators.
SynchronizedObserver(Observer<T>, AtomicObservableSubscription) - Constructor for class rx.util.SynchronizedObserver
 

T

take(Observable<T>, int) - Static method in class rx.Observable
Returns an Observable that emits the first num items emitted by the source Observable.
take(int) - Method in class rx.Observable
Returns an Observable that emits the first num items emitted by the source Observable.
take(Observable<T>, int) - Static method in class rx.operators.OperationTake
Returns a specified number of contiguous values from the start of an observable sequence.
takeLast(Observable<T>, int) - Static method in class rx.Observable
Returns an Observable that emits the last count items emitted by the source Observable.
takeLast(int) - Method in class rx.Observable
Returns an Observable that emits the last count items emitted by the source Observable.
takeLast(Observable<T>, int) - Static method in class rx.operators.OperationTakeLast
 
takeUntil(Observable<T>, Observable<E>) - Static method in class rx.Observable
Returns the values from the source observable sequence until the other observable sequence produces a value.
takeUntil(Observable<E>) - Method in class rx.Observable
Returns the values from the source observable sequence until the other observable sequence produces a value.
takeUntil(Observable<T>, Observable<E>) - Static method in class rx.operators.OperatorTakeUntil
Returns the values from the source observable sequence until the other observable sequence produces a value.
takeWhile(Observable<T>, Func1<T, Boolean>) - Static method in class rx.Observable
Returns a specified number of contiguous values from the start of an observable sequence.
takeWhile(Observable<T>, Object) - Static method in class rx.Observable
Returns a specified number of contiguous values from the start of an observable sequence.
takeWhile(Func1<T, Boolean>) - Method in class rx.Observable
Returns an Observable that items emitted by the source Observable as long as a specified condition is true.
takeWhile(Object) - Method in class rx.Observable
Returns a specified number of contiguous values from the start of an observable sequence.
takeWhile(Observable<T>, Func1<T, Boolean>) - Static method in class rx.operators.OperationTake
Returns a specified number of contiguous values from the start of an observable sequence.
takeWhileWithIndex(Observable<T>, Func2<T, Integer, Boolean>) - Static method in class rx.Observable
Returns values from an observable sequence as long as a specified condition is true, and then skips the remaining values.
takeWhileWithIndex(Observable<T>, Object) - Static method in class rx.Observable
 
takeWhileWithIndex(Func2<T, Integer, Boolean>) - Method in class rx.Observable
Returns values from an observable sequence as long as a specified condition is true, and then skips the remaining values.
takeWhileWithIndex(Object) - Method in class rx.Observable
Returns values from an observable sequence as long as a specified condition is true, and then skips the remaining values.
takeWhileWithIndex(Observable<T>, Func2<T, Integer, Boolean>) - Static method in class rx.operators.OperationTake
Returns values from an observable sequence as long as a specified condition is true, and then skips the remaining values.
testToIterator() - Method in class rx.operators.OperatorToIterator
 
testToIteratorWithException() - Method in class rx.operators.OperatorToIterator
 
toIterable(Observable<T>) - Static method in class rx.Observable
Converts an observable sequence to an Iterable.
toIterable() - Method in class rx.Observable
Converts an observable sequence to an Iterable.
toIterator(Observable<T>) - Static method in class rx.operators.OperatorToIterator
Returns an iterator that iterates all values of the observable.
toList(Observable<T>) - Static 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.Observable
Returns an Observable that emits a single item, a list composed of all the items emitted by the source Observable.
toObservable(Iterable<T>) - Static method in class rx.Observable
Converts an Iterable sequence to an Observable sequence.
toObservable(Future<T>) - Static method in class rx.Observable
Converts an Future to an Observable sequence.
toObservable(Future<T>, long, TimeUnit) - Static method in class rx.Observable
Converts an Future to an Observable sequence.
toObservable(T...) - Static method in class rx.Observable
Converts an Array sequence to an Observable sequence.
toObservableFuture(Future<T>) - Static method in class rx.operators.OperationToObservableFuture
 
toObservableFuture(Future<T>, long, TimeUnit) - Static method in class rx.operators.OperationToObservableFuture
 
toObservableIterable(Iterable<T>) - Static method in class rx.operators.OperationToObservableIterable
 
toObservableList(Observable<T>) - Static method in class rx.operators.OperationToObservableList
 
toSortedList(Observable<T>) - Static method in class rx.Observable
Sort T objects by their natural order (object must implement Comparable).
toSortedList(Observable<T>, Func2<T, T, Integer>) - Static method in class rx.Observable
Sort T objects using the defined sort function.
toSortedList(Observable<T>, Object) - Static method in class rx.Observable
Sort T objects using the defined sort function.
toSortedList() - Method in class rx.Observable
Sort T objects by their natural order (object must implement Comparable).
toSortedList(Func2<T, T, Integer>) - Method in class rx.Observable
Sort T objects using the defined sort function.
toSortedList(Object) - Method in class rx.Observable
Sort T objects using the defined sort function.
toSortedList(Observable<T>) - Static method in class rx.operators.OperationToObservableSortedList
Sort T objects by their natural order (object must implement Comparable).
toSortedList(Observable<T>, Func2<T, 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
 

U

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

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

wrap(Subscription) - Method in class rx.util.AtomicObservableSubscription
Wraps the actual subscription once it exists (if it wasn't available when constructed)

Z

zip(Observable<T0>, Observable<T1>, Func2<T0, T1, R>) - Static method in class rx.Observable
Returns an Observable that applies a function of your choosing to the combination of items emitted, in sequence, by two other Observables, with the results of this function becoming the sequence emitted by the returned Observable.
zip(Observable<T0>, Observable<T1>, Object) - Static method in class rx.Observable
Returns an Observable that applies a function of your choosing to the combination of items emitted, in sequence, by two other Observables, with the results of this function becoming the sequence emitted by the returned Observable.
zip(Observable<T0>, Observable<T1>, Observable<T2>, Func3<T0, T1, T2, R>) - Static method in class rx.Observable
Returns an Observable that applies a function of your choosing to the combination of items emitted, in sequence, by three other Observables, with the results of this function becoming the sequence emitted by the returned Observable.
zip(Observable<T0>, Observable<T1>, Observable<T2>, Object) - Static method in class rx.Observable
Returns an Observable that applies a function of your choosing to the combination of items emitted, in sequence, by three other Observables, with the results of this function becoming the sequence emitted by the returned Observable.
zip(Observable<T0>, Observable<T1>, Observable<T2>, Observable<T3>, Func4<T0, T1, T2, T3, R>) - Static method in class rx.Observable
Returns an Observable that applies a function of your choosing to the combination of items emitted, in sequence, by four other Observables, with the results of this function becoming the sequence emitted by the returned Observable.
zip(Observable<T0>, Observable<T1>, Observable<T2>, Observable<T3>, Object) - Static method in class rx.Observable
Returns an Observable that applies a function of your choosing to the combination of items emitted, in sequence, by four other Observables, with the results of this function becoming the sequence emitted by the returned Observable.
zip(Observable<T0>, Observable<T1>, Func2<T0, T1, R>) - Static method in class rx.operators.OperationZip
 
zip(Observable<T0>, Observable<T1>, Observable<T2>, Func3<T0, T1, T2, R>) - Static method in class rx.operators.OperationZip
 
zip(Observable<T0>, Observable<T1>, Observable<T2>, Observable<T3>, Func4<T0, T1, T2, T3, 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