See: Description
Class | Description |
---|---|
BlockingOperatorLatest |
Wait for and iterate over the latest values of the source observable.
|
BlockingOperatorMostRecent |
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.
|
BlockingOperatorNext |
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
|
BlockingOperatorToFuture |
Returns a Future representing the single value emitted by an Observable.
|
BlockingOperatorToIterator |
Returns an Iterator that iterates over all items emitted by a specified Observable.
|
BufferUntilSubscriber<T> |
A solution to the "time gap" problem that occurs with
groupBy and pivot . |
NotificationLite<T> |
For use in internal operators that need something like materialize and dematerialize wholly within the
implementation of the operator but don't want to incur the allocation cost of actually creating
Notification objects for every onNext and
onCompleted . |
OnSubscribeAmb<T> |
Given multiple
Observable s, propagates the one that first emits an item. |
OnSubscribeCache<T> |
This method has similar behavior to
Observable.replay() except that this auto-subscribes
to the source Observable rather than returning a connectable Observable. |
OnSubscribeCombineLatest<T,R> |
Returns an Observable that combines the emissions of multiple source observables.
|
OnSubscribeDefer<T> |
Do not create the Observable until an Observer subscribes; create a fresh Observable on each
subscription.
|
OnSubscribeDelay<T> |
Delays the emission of onNext events by a given amount of time.
|
OnSubscribeDelay.Emitter<T> |
Emits a value once the call() is invoked.
|
OnSubscribeDelaySubscription<T> |
Delays the subscription to the source by the given amount, running on the given scheduler.
|
OnSubscribeDelayWithSelector<T,U,V> |
Delay the subscription and emission of the source items by a per-item observable that fires its first element.
|
OnSubscribeFromIterable<T> |
Converts an
Iterable sequence into an Observable . |
OnSubscribeGroupJoin<T1,T2,D1,D2,R> |
Corrrelates two sequences when they overlap and groups the results.
|
OnSubscribeJoin<TLeft,TRight,TLeftDuration,TRightDuration,R> |
Correlates the elements of two sequences based on overlapping durations.
|
OnSubscribeMulticastSelector<TInput,TIntermediate,TResult> |
Returns an observable sequence that contains the elements of a sequence
produced by multicasting the source sequence within a selector function.
|
OnSubscribeRange |
Emit ints from start to end inclusive.
|
OnSubscribeRedo<T> | |
OnSubscribeRedo.RedoFinite | |
OnSubscribeRedo.RetryWithPredicate | |
OnSubscribeRefCount<T> |
Returns an observable sequence that stays connected to the source as long
as there is at least one subscription to the observable sequence.
|
OnSubscribeTimerOnce |
Timer that emits a single 0L and completes after the specified time.
|
OnSubscribeTimerPeriodically |
Emit 0L after the initial period and ever increasing number after each period.
|
OnSubscribeToObservableFuture |
Converts a
Future into an Observable . |
OnSubscribeUsing<T,Resource> |
Constructs an observable sequence that depends on a resource object.
|
OperatorAll<T> |
Returns an Observable that emits a Boolean that indicates whether all items emitted by an
Observable satisfy a condition.
|
OperatorAny<T> |
Returns an
Observable that emits true if any element of
an observable sequence satisfies a condition, otherwise false . |
OperatorAsObservable<T> |
Hides the identity of another observable.
|
OperatorBufferWithSingleObservable<T,TClosing> |
This operation takes
values from the specified
Observable source and stores them in a buffer until the
Observable constructed using the Func0 argument, produces a value. |
OperatorBufferWithSize<T> |
This operation takes
values from the specified
Observable source and stores them in all active chunks until the buffer
contains a specified number of elements. |
OperatorBufferWithStartEndObservable<T,TOpening,TClosing> |
This operation takes
values from the specified
Observable source and stores them in the currently active chunks. |
OperatorBufferWithTime<T> |
This operation takes
values from the specified
Observable source and stores them in a buffer. |
OperatorCast<T,R> |
Converts the elements of an observable sequence to the specified type.
|
OperatorConcat<T> |
Returns an Observable that emits the items emitted by two or more Observables, one after the other.
|
OperatorDebounceWithSelector<T,U> |
Delay the emission via another observable if no new source appears in the meantime.
|
OperatorDebounceWithTime<T> |
This operation filters out events which are published too quickly in succession.
|
OperatorDefaultIfEmpty<T> |
Returns the elements of the specified sequence or the specified default value
in a singleton sequence if the sequence is empty.
|
OperatorDematerialize<T> |
Reverses the effect of
OperatorMaterialize by transforming the Notification objects
emitted by a source Observable into the items or notifications they represent. |
OperatorDistinct<T,U> |
Returns an Observable that emits all distinct items emitted by the source.
|
OperatorDistinctUntilChanged<T,U> |
Returns an Observable that emits all sequentially distinct items emitted by the source.
|
OperatorDoOnEach<T> |
Converts the elements of an observable sequence to the specified type.
|
OperatorDoOnSubscribe<T> |
This operator modifies an
Observable so a given action is invoked when the Observable is subscribed. |
OperatorDoOnUnsubscribe<T> |
This operator modifies an
Observable so a given action is invoked when the Observable is unsubscribed. |
OperatorElementAt<T> |
Returns the element at a specified index in a sequence.
|
OperatorFilter<T> |
Filters an Observable by discarding any items it emits that do not meet some test.
|
OperatorFinally<T> |
Registers an action to be called after an Observable invokes
onComplete or onError . |
OperatorGroupBy<T,K,R> |
Groups the items emitted by an Observable according to a specified criterion, and emits these
grouped items as Observables, one Observable per group.
|
OperatorGroupByUntil<T,K,R,D> |
Groups the elements of an observable sequence according to a specified key selector, value selector and
duration selector function.
|
OperatorGroupByUntil.GroupSubject<K,R> |
A grouped observable with subject-like behavior.
|
OperatorMap<T,R> |
Applies a function of your choosing to every item emitted by an
Observable , and emits the results of
this transformation as a new Observable . |
OperatorMapNotification<T,R> |
Applies a function of your choosing to every item emitted by an
Observable , and emits the results of
this transformation as a new Observable . |
OperatorMapPair<T,U,R> |
An
Observable.Operator that pairs up items emitted by a source Observable with the sequence of items
emitted by the Observable that is derived from each item by means of a selector, and emits the
results of this pairing. |
OperatorMaterialize<T> |
Turns all of the notifications from an Observable into
onNext emissions, and marks
them with their original notification types within Notification objects. |
OperatorMerge<T> |
Flattens a list of
Observable s into one Observable , without any transformation. |
OperatorMergeDelayError<T> |
This behaves like
OperatorMerge except that if any of the merged Observables notify of
an error via onError , mergeDelayError will refrain from propagating that error
notification until all of the merged Observables have finished emitting items. |
OperatorMergeMaxConcurrent<T> |
Flattens a list of Observables into one Observable sequence, without any transformation.
|
OperatorMulticast<T,R> |
Shares a single subscription to a source through a Subject.
|
OperatorObserveOn<T> |
Delivers events on the specified
Scheduler asynchronously via an unbounded buffer. |
OperatorOnBackpressureBuffer<T> | |
OperatorOnBackpressureDrop<T> | |
OperatorOnErrorFlatMap<T> |
Allows inserting onNext events into a stream when onError events are received
and continuing the original sequence instead of terminating.
|
OperatorOnErrorResumeNextViaFunction<T> |
Instruct an Observable to pass control to another Observable (the return value of a function)
rather than invoking
onError if it encounters an error. |
OperatorOnErrorResumeNextViaObservable<T> |
Instruct an Observable to pass control to another Observable rather than invoking
onError if it encounters an error. |
OperatorOnErrorReturn<T> |
Instruct an Observable to emit a particular item to its Observer's
onNext method
rather than invoking onError if it encounters an error. |
OperatorOnExceptionResumeNextViaObservable<T> |
Instruct an Observable to pass control to another Observable rather than invoking
onError if it encounters an error of type Exception . |
OperatorReplay |
Replay with limited buffer and/or time constraints.
|
OperatorReplay.SubjectWrapper<T> |
A subject that wraps another subject.
|
OperatorRetryWithPredicate<T> | |
OperatorSampleWithObservable<T,U> |
Sample with the help of another observable.
|
OperatorSampleWithTime<T> |
Returns an Observable that emits the results of sampling the items emitted by the source
Observable at a specified time interval.
|
OperatorScan<R,T> |
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.
|
OperatorSequenceEqual |
Returns an
Observable that emits a single Boolean value that indicates whether two source
Observable s emit sequences of items that are equivalent to each other. |
OperatorSerialize<T> | |
OperatorSingle<T> |
If the Observable completes after emitting a single item that matches a
predicate, return an Observable containing that item.
|
OperatorSkip<T> |
Returns an Observable that skips the first
num items emitted by the source
Observable. |
OperatorSkipLast<T> |
Bypasses a specified number of elements at the end of an observable sequence.
|
OperatorSkipLastTimed<T> |
Skip delivering values in the time window before the values.
|
OperatorSkipTimed<T> |
Skips elements until a specified time elapses.
|
OperatorSkipUntil<T,U> |
Skip elements from the source Observable until the secondary
observable fires an element.
|
OperatorSkipWhile<T> |
Skips any emitted source items as long as the specified condition holds true.
|
OperatorSubscribeOn<T> |
Subscribes Observers on the specified
Scheduler . |
OperatorSwitch<T> |
Transforms an Observable that emits Observables into a single Observable that
emits the items emitted by the most recently published of those Observables.
|
OperatorTake<T> |
An
Observable that emits the first num items emitted by the source Observable . |
OperatorTakeLast<T> |
Returns an Observable that emits the last
count items emitted by the source Observable. |
OperatorTakeLastTimed<T> |
Returns an Observable that emits the last
count items emitted by the source Observable. |
OperatorTakeTimed<T> |
Takes values from the source until the specific time ellapses.
|
OperatorTakeUntil<T,E> |
Returns an Observable that emits the items from the source Observable until another Observable
emits an item.
|
OperatorTakeWhile<T> |
Returns an Observable that emits items emitted by the source Observable as long as a specified
condition is true.
|
OperatorThrottleFirst<T> |
Throttle by windowing a stream and returning the first value in each window.
|
OperatorTimeInterval<T> |
Records the time interval between consecutive elements in an observable sequence.
|
OperatorTimeout<T> |
Applies a timeout policy for each element in the observable sequence, using
the specified scheduler to run timeout timers.
|
OperatorTimeoutWithSelector<T,U,V> |
Returns an Observable that mirrors the source Observable.
|
OperatorTimestamp<T> |
Wraps each item emitted by a source
Observable in a Timestamped object. |
OperatorToMap<T,K,V> |
Maps the elements of the source observable into a java.util.Map instance and
emits that once the source observable completes.
|
OperatorToMap.DefaultToMapFactory<K,V> |
The default map factory.
|
OperatorToMultimap<T,K,V> |
Maps the elements of the source observable into a multimap
(Map<K, Collection<V>>) where each
key entry has a collection of the source's values.
|
OperatorToMultimap.DefaultMultimapCollectionFactory<K,V> |
The default collection factory for a key in the multimap returning
an ArrayList independent of the key.
|
OperatorToMultimap.DefaultToMultimapFactory<K,V> |
The default multimap factory returning a HashMap.
|
OperatorToObservableList<T> |
Returns an
Observable that emits a single item, a list composed of all the items emitted by the
source Observable . |
OperatorToObservableSortedList<T> |
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). |
OperatorUnsubscribeOn<T> |
Unsubscribes on the specified Scheduler.
|
OperatorWindowWithObservable<T,U> |
Creates non-overlapping windows of items where each window is terminated by
an event from a secondary observable and a new window is started immediately.
|
OperatorWindowWithSize<T> |
Creates windows of values into the source sequence with skip frequency and size bounds.
|
OperatorWindowWithStartEndObservable<T,U,V> |
Creates potentially overlapping windows of the source items where each window is
started by a value emitted by an observable and closed when an associated Observable emits
a value or completes.
|
OperatorWindowWithTime<T> |
Creates windows of values into the source sequence with timed window creation, length and size bounds.
|
OperatorZip<R> |
Returns an Observable that emits the results of a function applied to sets of items emitted, in
sequence, by two or more other Observables.
|
OperatorZipIterable<T1,T2,R> |
Operators that allow composing Observables to transform and manipulate data in an asynchronous, functional and thread-safe manner.
The operators are all exposed via the ObservableExtensions class