Uses of Interface
rx.functions.Function
Packages that use Function
Package
Description
Base reactive classes: Observable, Single and Completable; base reactive consumers;
other common base interfaces.
Functional interfaces of functions and actions of arity 0 to 9 and related
utility classes.
Operators that allow composing Observables to transform and
manipulate data in an asynchronous, functional and thread-safe manner.
Classes extending the Observable base reactive class, synchronous and
asynchronous event generators.
Classes extending the Observable base reactive class and implementing
the Observer interface at the same time (aka hot Observables).
-
Uses of Function in rx
Modifier and TypeInterfaceDescriptionstatic interface
Callback used for building deferred computations that takes a CompletableSubscriber.static interface
Convenience interface and callback used by the lift operator that given a child CompletableSubscriber, return a parent CompletableSubscriber that does any kind of lifecycle-related transformations.static interface
Convenience interface and callback used by the compose operator to turn a Completable into another Completable fluently.static interface
Invoked when Observable.subscribe is called.static interface
Observable.Operator<R,
T> Operator function for lifting into an Observable.static interface
Function that receives the current Observable and should return another Observable, possibly with given element type, in exchange that will be subscribed to by the downstream operators and subscribers.static interface
Invoked when Single.execute is called.static interface
Single.Transformer<T,
R> Transformer function used bySingle.compose(rx.Single.Transformer<? super T, ? extends R>)
.Modifier and TypeClassDescription(package private) static final class
Transforms a OnSubscribe.call() into an Observable.subscribe() call. -
Uses of Function in rx.functions
Subinterfaces of Function in rx.functionsModifier and TypeInterfaceDescriptioninterface
All Action interfaces extend from this.interface
A zero-argument action.interface
Action1<T>
A one-argument action.interface
Action2<T1,
T2> A two-argument action.interface
Action3<T1,
T2, T3> A three-argument action.interface
Action4<T1,
T2, T3, T4> A four-argument action.interface
Action5<T1,
T2, T3, T4, T5> A five-argument action.interface
Action6<T1,
T2, T3, T4, T5, T6> A six-argument action.interface
Action7<T1,
T2, T3, T4, T5, T6, T7> A seven-argument action.interface
Action8<T1,
T2, T3, T4, T5, T6, T7, T8> An eight-argument action.interface
Action9<T1,
T2, T3, T4, T5, T6, T7, T8, T9> A nine-argument action.interface
A vector-argument action.interface
Func0<R>
Represents a function with zero arguments.interface
Func1<T,
R> Represents a function with one argument.interface
Func2<T1,
T2, R> Represents a function with two arguments.interface
Func3<T1,
T2, T3, R> Represents a function with three arguments.interface
Func4<T1,
T2, T3, T4, R> Represents a function with four arguments.interface
Func5<T1,
T2, T3, T4, T5, R> Represents a function with five arguments.interface
Func6<T1,
T2, T3, T4, T5, T6, R> Represents a function with six arguments.interface
Func7<T1,
T2, T3, T4, T5, T6, T7, R> Represents a function with seven arguments.interface
Func8<T1,
T2, T3, T4, T5, T6, T7, T8, R> Represents a function with eight arguments.interface
Func9<T1,
T2, T3, T4, T5, T6, T7, T8, T9, R> Represents a function with nine arguments.interface
FuncN<R>
Represents a vector-argument function.Classes in rx.functions that implement FunctionModifier and TypeClassDescription(package private) static final class
(package private) static final class
Actions.EmptyAction<T0,
T1, T2, T3, T4, T5, T6, T7, T8> -
Uses of Function in rx.internal.operators
Subinterfaces of Function in rx.internal.operatorsModifier and TypeInterfaceDescription(package private) static interface
Set up the timeout action on the first value.(package private) static interface
Set up the timeout action based on every valueClasses in rx.internal.operators that implement FunctionModifier and TypeClassDescription(package private) static final class
(package private) static final class
Manages the subscription of child subscribers by setting up a replay producer and performs auto-connection of the very first subscription.final class
final class
final class
final class
final class
final class
final class
final class
final class
enum
Holds a singleton instance of an empty Observable which is stateless and completes the child subscriber immediately.enum
Holds a singleton instance of a never Observable which is stateless doesn't call any of the Subscriber's methods.final class
Given multipleObservable
s, propagates the one that first emits an item.final class
Wraps a ConnectableObservable and calls its connect() method once the specified number of Subscribers have subscribed.final class
OnSubscribeCollect<T,
R> final class
final class
OnSubscribeConcatMap<T,
R> Maps a source sequence into Observables and concatenates them in order, subscribing to one at a time.final class
Do not create the Observable until an Observer subscribes; create a fresh Observable on each subscription.final class
Delays the subscription to the source by the given amount, running on the given scheduler.final class
Delays the subscription to the main source until the other observable fires an event or completes.final class
Delays the subscription until the Observable emits an event.final class
Nulls out references to upstream data structures when the source terminates or the child unsubscribes.final class
Filters an Observable by discarding any items it emits that do not meet some test.final class
Flattens a sequence if Iterable sources, generated via a function, into a single sequence.(package private) static final class
A custom flattener that works from a scalar value and computes the iterable during subscription time.final class
final class
final class
Do not invoke the function until an Observer subscribes; Invokes function on each subscription.final class
Converts anIterable
sequence into anObservable
.final class
OnSubscribeGroupJoin<T1,
T2, D1, D2, R> Correlates two sequences when they overlap and groups the results.(package private) static final class
The reference-counted window observable.final class
OnSubscribeJoin<TLeft,
TRight, TLeftDuration, TRightDuration, R> Correlates the elements of two sequences based on overlapping durations.final class
OnSubscribeLift<T,
R> Transforms the downstream Subscriber into a Subscriber via an operator callback and calls the parent OnSubscribe.call() method with it.final class
OnSubscribeMap<T,
R> Applies a function of your choosing to every item emitted by anObservable
, and emits the results of this transformation as a newObservable
.final class
Captures the current stack when it is instantiated, makes it available through a field and attaches it to all passing exception.final class
Captures the current stack when it is instantiated, makes it available through a field and attaches it to all passing exception.final class
Captures the current stack when it is instantiated, makes it available through a field and attaches it to all passing exception.final class
Multicasts notifications coming through its input Subscriber view to its client Subscribers via lockstep backpressure mode.final class
Emit ints from start to end inclusive.final class
static final class
static final class
final class
final class
final class
Returns an observable sequence that stays connected to the source as long as there is at least one subscription to the observable sequence.class
Allows conversion of an Observable to a Single ensuring that exactly one item is emitted - no more and no less.final class
final class
final class
Timer that emits a single 0L and completes after the specified time.final class
Emit 0L after the initial period and ever increasing number after each period.(package private) static class
final class
OnSubscribeUsing<T,
Resource> Constructs an observable sequence that depends on a resource object.(package private) static final class
OnSubscribeUsing.DisposeAction<Resource>
final class
OperatorAll<T>
Returns an Observable that emits a Boolean that indicates whether all items emitted by an Observable satisfy a condition.final class
OperatorAny<T>
Returns anObservable
that emitstrue
if any element of an observable sequence satisfies a condition, otherwisefalse
.final class
Hides the identity of another observable.final class
OperatorBufferWithSingleObservable<T,
TClosing> This operation takes values from the specifiedObservable
source and stores them in a buffer until theObservable
constructed using theFunc0
argument, produces a value.final class
This operation takes values from the specifiedObservable
source and stores them in all active chunks until the buffer contains a specified number of elements.final class
OperatorBufferWithStartEndObservable<T,
TOpening, TClosing> This operation takes values from the specifiedObservable
source and stores them in the currently active chunks.final class
This operation takes values from the specifiedObservable
source and stores them in a buffer.class
OperatorCast<T,
R> Converts the elements of an observable sequence to the specified type.final class
Delay the emission via another observable if no new source appears in the meantime.final class
This operation filters out events which are published too quickly in succession.final class
Delays the emission of onNext events by a given amount of time.final class
Delay the subscription and emission of the source items by a per-item observable that fires its first element.final class
Reverses the effect ofOperatorMaterialize
by transforming the Notification objects emitted by a source Observable into the items or notifications they represent.final class
OperatorDistinct<T,
U> Returns an Observable that emits all distinct items emitted by the source.final class
Returns an Observable that emits all sequentially distinct items emitted by the source.final class
Registers an action to be called after an Observable invokesonComplete
oronError
.class
Converts the elements of an observable sequence to the specified type.class
This operator modifies anObservable
so a given action is invoked when theProducer
receives a request.class
This operator modifies anObservable
so a given action is invoked when theObservable
is subscribed.class
This operator modifies anObservable
so a given action is invoked when theObservable
is unsubscribed.final class
final class
Returns the element at a specified index in a sequence.final class
OperatorGroupBy<T,
K, V> Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as Observables, one Observable per group.(package private) static class
(package private) static final class
class
final class
Applies a function of your choosing to every item emitted by anObservable
, and emits the results of this transformation as a newObservable
.final class
OperatorMapPair<T,
U, R> AnObservable.Operator
that pairs up items emitted by a sourceObservable
with the sequence of items emitted by theObservable
that is derived from each item by means of a selector, and emits the results of this pairing.(package private) static final class
final class
Turns all of the notifications from an Observable intoonNext
emissions, and marks them with their original notification types withinNotification
objects.final class
Flattens a list ofObservable
s into oneObservable
, without any transformation.final class
Delivers events on the specifiedScheduler
asynchronously via an unbounded buffer.(package private) static final class
Observe through individual queue per observer.class
class
final class
An operator which drops all but the last received value in case the downstream doesn't request more.final class
Instruct an Observable to pass control to another Observable (the return value of a function) rather than invokingonError
if it encounters an error.final class
final class
Sample with the help of another observable.final class
Returns an Observable that emits the results of sampling the items emitted by the source Observable at a specified time interval.(package private) static final class
The source subscriber and sampler.final class
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.final class
final class
If the Observable completes after emitting a single item that matches a predicate, return an Observable containing that item.final class
OperatorSkip<T>
Returns an Observable that skips the firstnum
items emitted by the source Observable.class
Bypasses a specified number of elements at the end of an observable sequence.class
Skip delivering values in the time window before the values.final class
Skips elements until a specified time elapses.final class
OperatorSkipUntil<T,
U> Skip elements from the source Observable until the secondary observable fires an element.final class
Skips any emitted source items as long as the specified condition holds true.final class
Subscribes Observers on the specifiedScheduler
.final class
Transforms an Observable that emits Observables into a single Observable that emits the items emitted by the most recently published of those Observables.final class
If the Observable completes without emitting any items, subscribe to an alternate Observable.final class
OperatorTake<T>
AnObservable
that emits the firstnum
items emitted by the sourceObservable
.final class
Returns an Observable that emits the at most the lastcount
items emitted by the source Observable.(package private) static final class
final class
Returns an Observable that emits the lastcount
items emitted by the source Observable.(package private) static final class
final class
Takes values from the source until the specific time elapses.(package private) static final class
Subscribed to source and scheduled on a worker.final class
OperatorTakeUntil<T,
E> Returns an Observable that emits the items from the source Observable until another Observable emits an item.final class
Returns an Observable that emits items emitted by the source Observable until the provided predicate returns falsefinal class
O Returns an Observable that emits items emitted by the source Observable as long as a specified condition is true.final class
Throttle by windowing a stream and returning the first value in each window.final class
Records the time interval between consecutive elements in an observable sequence.final class
Applies a timeout policy for each element in the observable sequence, using the specified scheduler to run timeout timers.(package private) class
class
OperatorTimeoutWithSelector<T,
U, V> Returns an Observable that mirrors the source Observable.final class
Wraps each item emitted by a sourceObservable
in aTimestamped
object.final class
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.static final class
The default map factory.final class
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.static final class
The default collection factory for a key in the multimap returning an ArrayList independent of the key.static final class
The default multimap factory returning a HashMap.final class
Returns anObservable
that emits a single item, a list composed of all the items emitted by the sourceObservable
.final class
Return anObservable
that emits the items emitted by the sourceObservable
, in a sorted order (each item emitted by theObservable
must implementComparable
with respect to all other items in the sequence, or you must pass in a sort function).class
Unsubscribes on the specified Scheduler.final class
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.final class
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.final class
Creates windows of values into the source sequence with skip frequency and size bounds.(package private) static final class
(package private) static final class
(package private) static final class
final class
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.final class
Creates windows of values into the source sequence with timed window creation, length and size bounds.final class
OperatorWithLatestFrom<T,
U, R> Combines values from two sources only when the main source emits.final class
final class
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.final class
OperatorZipIterable<T1,
T2, R> final class
Execute an action after onSuccess or onError has been delivered.final class
Delays the subscription to the Single until the Observable fires an event or completes.final class
SingleOnSubscribeMap<T,
R> Applies a function of your choosing to every item emitted by anSingle
, and emits the results of this transformation as a newSingle
.final class
SingleOnSubscribeUsing<T,
Resource> Generates a resource, derives a Single from it and disposes that resource once the Single terminates.final class
-
Uses of Function in rx.internal.schedulers
Classes in rx.internal.schedulers that implement Function -
Uses of Function in rx.internal.util
Classes in rx.internal.util that implement FunctionModifier and TypeClassDescription(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
The OnSubscribe callback for the Observable constructor.(package private) static final class
The OnSubscribe implementation that creates the ScalarAsyncProducer for each incoming subscriber.(package private) static final class
Represents a producer which schedules the emission of a scalar value on the first positive request via the given scheduler callback.(package private) static final class
Optimized observeOn for scalar value observed on the EventLoopsScheduler.(package private) static final class
Emits a scalar value on a general scheduler.(package private) static final class
Action that emits a single value when called.(package private) static enum
(package private) static enum
-
Uses of Function in rx.observables
Classes in rx.observables that implement FunctionModifier and TypeClassDescriptionclass
AsyncOnSubscribe<S,
T> A utility class to createOnSubscribe<T>
functions that respond correctly to back pressure requests from subscribers.(package private) static final class
An implementation of AsyncOnSubscribe that delegatesAsyncOnSubscribe.next(Object, long, Observer)
,AsyncOnSubscribe.generateState()
, andAsyncOnSubscribe.onUnsubscribe(Object)
to provided functions/closures.(package private) static final class
class
SyncOnSubscribe<S,
T> A utility class to createOnSubscribe<T>
functions that respond correctly to back pressure requests from subscribers.(package private) static final class
An implementation of SyncOnSubscribe that delegatesinvalid reference
SyncOnSubscribe#next(Object, Subscriber)
SyncOnSubscribe.generateState()
, andSyncOnSubscribe.onUnsubscribe(Object)
to provided functions/closures. -
Uses of Function in rx.subjects
Classes in rx.subjects that implement FunctionModifier and TypeClassDescription(package private) static final class
Holds onto the array of Subscriber-wrapping ReplayProducers and the buffer that holds values to be replayed; it manages subscription and signal dispatching.(package private) final class
Represents the typical state and OnSubscribe logic for a Subject implementation.(package private) static final class
The single-consumption replaying state.