Uses of Interface
rx.functions.Action0
-
Packages that use Action0 Package Description rx Base reactive classes: Observable, Single and Completable; base reactive consumers; other common base interfaces.rx.functions Functional interfaces of functions and actions of arity 0 to 9 and related utility classes.rx.internal.operators Operators that allow composing Observables to transform and manipulate data in an asynchronous, functional and thread-safe manner.rx.internal.schedulers rx.internal.util rx.observables Classes extending the Observable base reactive class, synchronous and asynchronous event generators.rx.observers Default wrappers and implementations for the base reactive consumer classes and interfaces; utility classes for creating them from callbacks.rx.plugins Callback types and a central plugin handler class to hook into the lifecycle of the base reactive types and schedulers.rx.schedulers Scheduler implementations, value+time record classes and the standard factory class to return standard RxJava schedulers or wrap any Executor-based (thread pool) instances.rx.subjects Classes extending the Observable base reactive class and implementing the Observer interface at the same time (aka hot Observables).rx.subscriptions Default implementations for Subscription-based resource management (Subscription container types) and utility classes to construct Subscriptions from callbacks and other types. -
-
Uses of Action0 in rx
Methods in rx with parameters of type Action0 Modifier and Type Method Description Completable
Completable. doAfterTerminate(Action0 onAfterComplete)
Returns a Completable instance that calls the given onAfterComplete callback after this Completable completes normally.Observable<T>
Observable. doAfterTerminate(Action0 action)
Single<T>
Single. doAfterTerminate(Action0 action)
Registers anAction0
to be called when thisSingle
invokes eitherSingleSubscriber.onSuccess(Object)
onSuccess} oronError
.Completable
Completable. doOnComplete(Action0 onComplete)
Deprecated.UseCompletable.doOnCompleted(Action0)
instead.Completable
Completable. doOnCompleted(Action0 onCompleted)
Returns a Completable which calls the given onCompleted callback if this Completable completes.Observable<T>
Observable. doOnCompleted(Action0 onCompleted)
Modifies the source Observable so that it invokes an action when it callsonCompleted
.protected Completable
Completable. doOnLifecycle(Action1<? super Subscription> onSubscribe, Action1<? super java.lang.Throwable> onError, Action0 onComplete, Action0 onAfterComplete, Action0 onUnsubscribe)
Returns a Completable instance that calls the various callbacks on the specific lifecycle events.Observable<T>
Observable. doOnSubscribe(Action0 subscribe)
Modifies the sourceObservable
so that it invokes the given action when it is subscribed from its subscribers.Single<T>
Single. doOnSubscribe(Action0 subscribe)
Modifies the sourceSingle
so that it invokes the given action when it is subscribed from its subscribers.Completable
Completable. doOnTerminate(Action0 onTerminate)
Returns a Completable instance that calls the given onTerminate callback just before this Completable completes normally or with an exceptionObservable<T>
Observable. doOnTerminate(Action0 onTerminate)
Modifies the source Observable so that it invokes an action when it callsonCompleted
oronError
.Completable
Completable. doOnUnsubscribe(Action0 onUnsubscribe)
Returns a Completable which calls the given onUnsubscribe callback if the child subscriber cancels the subscription.Observable<T>
Observable. doOnUnsubscribe(Action0 unsubscribe)
Calls the unsubscribeAction0
if the downstream unsubscribes the sequence.Single<T>
Single. doOnUnsubscribe(Action0 action)
Modifies the sourceSingle
so that it invokes the given action when it is unsubscribed from its subscribers.Observable<T>
Observable. finallyDo(Action0 action)
Deprecated.useObservable.doAfterTerminate(Action0)
instead.void
Observable. forEach(Action1<? super T> onNext, Action1<java.lang.Throwable> onError, Action0 onComplete)
Subscribes to theObservable
and receives notifications for each element and the terminal events.static Completable
Completable. fromAction(Action0 action)
Returns a Completable instance that runs the given Action0 for each subscriber and emits either an unchecked exception or simply completes.Observable<T>
Observable. onBackpressureBuffer(long capacity, Action0 onOverflow)
Instructs an Observable that is emitting items faster than its observer can consume them to buffer up to a given amount of items until they can be emitted.Observable<T>
Observable. onBackpressureBuffer(long capacity, Action0 onOverflow, BackpressureOverflow.Strategy overflowStrategy)
Instructs an Observable that is emitting items faster than its observer can consume them to buffer up to a given amount of items until they can be emitted.abstract Subscription
Scheduler.Worker. schedule(Action0 action)
Schedules an Action for execution.abstract Subscription
Scheduler.Worker. schedule(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
Schedules an Action for execution at some point in the future.Subscription
Scheduler.Worker. schedulePeriodically(Action0 action, long initialDelay, long period, java.util.concurrent.TimeUnit unit)
Schedules a cancelable action to be executed periodically.Subscription
Completable. subscribe(Action0 onComplete)
Subscribes to this Completable and calls the given Action0 when this Completable completes normally.Subscription
Completable. subscribe(Action0 onComplete, Action1<? super java.lang.Throwable> onError)
Subscribes to this Completable and calls back either the onError or onComplete functions.Subscription
Observable. subscribe(Action1<? super T> onNext, Action1<java.lang.Throwable> onError, Action0 onCompleted)
Subscribes to an Observable and provides callbacks to handle the items it emits and any error or completion notification it issues. -
Uses of Action0 in rx.functions
Classes in rx.functions that implement Action0 Modifier and Type Class Description (package private) static class
Actions.EmptyAction<T0,T1,T2,T3,T4,T5,T6,T7,T8>
Fields in rx.functions declared as Action0 Modifier and Type Field Description (package private) Action0
Actions.Action1CallsAction0. action
Methods in rx.functions with parameters of type Action0 Modifier and Type Method Description static FuncN<java.lang.Void>
Functions. fromAction(Action0 f)
static <T> Action1<T>
Actions. toAction1(Action0 action)
Wraps an Action0 instance into an Action1 instance where the latter calls the former.static Func0<java.lang.Void>
Actions. toFunc(Action0 action)
Converts anAction0
to a function that calls the action and returnsnull
.static <R> Func0<R>
Actions. toFunc(Action0 action, R result)
Converts anAction0
to a function that calls the action and returns a specified value.Constructors in rx.functions with parameters of type Action0 Constructor Description Action1CallsAction0(Action0 action)
-
Uses of Action0 in rx.internal.operators
Classes in rx.internal.operators that implement Action0 Modifier and Type Class Description (package private) static class
OnSubscribeUsing.DisposeAction<Resource>
(package private) static class
OperatorObserveOn.ObserveOnSubscriber<T>
Observe through individual queue per observer.(package private) static class
OperatorSampleWithTime.SamplerSubscriber<T>
The source subscriber and sampler.(package private) static class
OperatorTakeTimed.TakeSubscriber<T>
Subscribed to source and scheduled on a worker.(package private) static class
OperatorWindowWithSize.WindowExact<T>
(package private) static class
OperatorWindowWithSize.WindowOverlap<T>
(package private) static class
OperatorWindowWithSize.WindowSkip<T>
Fields in rx.internal.operators declared as Action0 Modifier and Type Field Description (package private) Action0
OperatorDoAfterTerminate. action
(package private) Action0
SingleDoAfterTerminate. action
(package private) Action0
SingleDoAfterTerminate.SingleDoAfterTerminateSubscriber. action
private Action0
OperatorOnBackpressureBuffer.BufferSubscriber. onOverflow
private Action0
OperatorOnBackpressureBuffer. onOverflow
private Action0
OperatorDoOnSubscribe. subscribe
private Action0
OperatorDoOnUnsubscribe. unsubscribe
Methods in rx.internal.operators with parameters of type Action0 Modifier and Type Method Description private java.lang.Throwable
OnSubscribeUsing. dispose(Action0 disposeOnceOnly)
Constructors in rx.internal.operators with parameters of type Action0 Constructor Description BufferSubscriber(Subscriber<? super T> child, java.lang.Long capacity, Action0 onOverflow, BackpressureOverflow.Strategy overflowStrategy)
OperatorDoAfterTerminate(Action0 action)
OperatorDoOnSubscribe(Action0 subscribe)
Constructs an instance of the operator with the callback that gets invoked when the modified Observable is subscribedOperatorDoOnUnsubscribe(Action0 unsubscribe)
Constructs an instance of the operator with the callback that gets invoked when the modified Observable is unsubscribedOperatorOnBackpressureBuffer(long capacity, Action0 onOverflow)
Construct a new instance that will handle overflows withON_OVERFLOW_DEFAULT
, providing the following behavior config:OperatorOnBackpressureBuffer(long capacity, Action0 onOverflow, BackpressureOverflow.Strategy overflowStrategy)
Construct a new instance feeding the following behavior config:SingleDoAfterTerminate(Single<T> source, Action0 action)
SingleDoAfterTerminateSubscriber(SingleSubscriber<? super T> actual, Action0 action)
-
Uses of Action0 in rx.internal.schedulers
Classes in rx.internal.schedulers that implement Action0 Modifier and Type Class Description (package private) class
SleepingAction
Fields in rx.internal.schedulers declared as Action0 Modifier and Type Field Description (package private) Action0
ScheduledAction. action
private Action0
SchedulerWhen.DelayedAction. action
private Action0
SchedulerWhen.ImmediateAction. action
(package private) Action0
TrampolineScheduler.TimedAction. action
private Action0
SleepingAction. underlying
Methods in rx.internal.schedulers with parameters of type Action0 Modifier and Type Method Description private Subscription
TrampolineScheduler.InnerCurrentThreadScheduler. enqueue(Action0 action, long execTime)
Subscription
CachedThreadScheduler.EventLoopWorker. schedule(Action0 action)
Subscription
CachedThreadScheduler.EventLoopWorker. schedule(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
Subscription
EventLoopsScheduler.EventLoopWorker. schedule(Action0 action)
Subscription
EventLoopsScheduler.EventLoopWorker. schedule(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
Subscription
ExecutorScheduler.ExecutorSchedulerWorker. schedule(Action0 action)
Subscription
ExecutorScheduler.ExecutorSchedulerWorker. schedule(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
Subscription
ImmediateScheduler.InnerImmediateScheduler. schedule(Action0 action)
Subscription
ImmediateScheduler.InnerImmediateScheduler. schedule(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
Subscription
NewThreadWorker. schedule(Action0 action)
Subscription
NewThreadWorker. schedule(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
Subscription
TrampolineScheduler.InnerCurrentThreadScheduler. schedule(Action0 action)
Subscription
TrampolineScheduler.InnerCurrentThreadScheduler. schedule(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
ScheduledAction
NewThreadWorker. scheduleActual(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
Schedules the given action by wrapping it into a ScheduledAction on the underlying ExecutorService, returning the ScheduledAction.ScheduledAction
NewThreadWorker. scheduleActual(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit, SubscriptionList parent)
ScheduledAction
NewThreadWorker. scheduleActual(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit, CompositeSubscription parent)
Subscription
EventLoopsScheduler. scheduleDirect(Action0 action)
Schedules the action directly on one of the event loop workers without the additional infrastructure and checking.Constructors in rx.internal.schedulers with parameters of type Action0 Constructor Description DelayedAction(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
ImmediateAction(Action0 action)
ScheduledAction(Action0 action)
ScheduledAction(Action0 action, SubscriptionList parent)
ScheduledAction(Action0 action, CompositeSubscription parent)
SleepingAction(Action0 underlying, Scheduler.Worker scheduler, long execTime)
TimedAction(Action0 action, java.lang.Long execTime, int count)
-
Uses of Action0 in rx.internal.util
Classes in rx.internal.util that implement Action0 Modifier and Type Class Description (package private) static class
ScalarSynchronousObservable.ScalarAsyncProducer<T>
Represents a producer which schedules the emission of a scalar value on the first positive request via the given scheduler callback.(package private) static class
ScalarSynchronousSingle.ScalarSynchronousSingleAction<T>
Action that emits a single value when called.Fields in rx.internal.util declared as Action0 Modifier and Type Field Description (package private) Action0
ActionSubscriber. onCompleted
Fields in rx.internal.util with type parameters of type Action0 Modifier and Type Field Description (package private) Func1<Action0,Subscription>
ScalarSynchronousObservable.ScalarAsyncOnSubscribe. onSchedule
(package private) Func1<Action0,Subscription>
ScalarSynchronousObservable.ScalarAsyncProducer. onSchedule
Constructors in rx.internal.util with parameters of type Action0 Constructor Description ActionSubscriber(Action1<? super T> onNext, Action1<java.lang.Throwable> onError, Action0 onCompleted)
Constructor parameters in rx.internal.util with type arguments of type Action0 Constructor Description ScalarAsyncOnSubscribe(T value, Func1<Action0,Subscription> onSchedule)
ScalarAsyncProducer(Subscriber<? super T> actual, T value, Func1<Action0,Subscription> onSchedule)
-
Uses of Action0 in rx.observables
Methods in rx.observables with parameters of type Action0 Modifier and Type Method Description static <T> AsyncOnSubscribe<java.lang.Void,T>
AsyncOnSubscribe. createStateless(Action2<java.lang.Long,? super Observer<Observable<? extends T>>> next, Action0 onUnsubscribe)
Generates a synchronousAsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <T> SyncOnSubscribe<java.lang.Void,T>
SyncOnSubscribe. createStateless(Action1<? super Observer<? super T>> next, Action0 onUnsubscribe)
Generates a synchronousSyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.void
BlockingObservable. subscribe(Action1<? super T> onNext, Action1<? super java.lang.Throwable> onError, Action0 onCompleted)
Subscribes to the source and calls the given actions on the current thread. -
Uses of Action0 in rx.observers
Methods in rx.observers with parameters of type Action0 Modifier and Type Method Description static <T> Observer<T>
Observers. create(Action1<? super T> onNext, Action1<java.lang.Throwable> onError, Action0 onComplete)
Creates anObserver
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
oronCompleted
notifications.static <T> Subscriber<T>
Subscribers. create(Action1<? super T> onNext, Action1<java.lang.Throwable> onError, Action0 onComplete)
Creates anSubscriber
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
oronCompleted
notifications. -
Uses of Action0 in rx.plugins
Fields in rx.plugins with type parameters of type Action0 Modifier and Type Field Description (package private) static Func1<Action0,Action0>
RxJavaHooks. onScheduleAction
(package private) static Func1<Action0,Action0>
RxJavaHooks. onScheduleAction
Methods in rx.plugins that return Action0 Modifier and Type Method Description Action0
RxJavaSchedulersHook. onSchedule(Action0 action)
Deprecated.static Action0
RxJavaHooks. onScheduledAction(Action0 action)
Hook to call before the action is scheduled, allows decorating the original action.Methods in rx.plugins that return types with arguments of type Action0 Modifier and Type Method Description static Func1<Action0,Action0>
RxJavaHooks. getOnScheduleAction()
Returns the current schedule action hook function or null if it is set to the default pass-through.static Func1<Action0,Action0>
RxJavaHooks. getOnScheduleAction()
Returns the current schedule action hook function or null if it is set to the default pass-through.Methods in rx.plugins with parameters of type Action0 Modifier and Type Method Description Action0
RxJavaSchedulersHook. onSchedule(Action0 action)
Deprecated.static Action0
RxJavaHooks. onScheduledAction(Action0 action)
Hook to call before the action is scheduled, allows decorating the original action.Method parameters in rx.plugins with type arguments of type Action0 Modifier and Type Method Description static void
RxJavaHooks. setOnScheduleAction(Func1<Action0,Action0> onScheduleAction)
Sets the hook function that is called before an action is scheduled, allowing decorating that function, unless a lockdown is in effect.static void
RxJavaHooks. setOnScheduleAction(Func1<Action0,Action0> onScheduleAction)
Sets the hook function that is called before an action is scheduled, allowing decorating that function, unless a lockdown is in effect. -
Uses of Action0 in rx.schedulers
Fields in rx.schedulers declared as Action0 Modifier and Type Field Description (package private) Action0
TestScheduler.TimedAction. action
Methods in rx.schedulers with parameters of type Action0 Modifier and Type Method Description Subscription
TestScheduler.InnerTestScheduler. schedule(Action0 action)
Subscription
TestScheduler.InnerTestScheduler. schedule(Action0 action, long delayTime, java.util.concurrent.TimeUnit unit)
Constructors in rx.schedulers with parameters of type Action0 Constructor Description TimedAction(Scheduler.Worker scheduler, long time, Action0 action)
-
Uses of Action0 in rx.subjects
Fields in rx.subjects with type parameters of type Action0 Modifier and Type Field Description (package private) java.util.concurrent.atomic.AtomicReference<Action0>
UnicastSubject.State. terminateOnce
Atomically set to true on terminal condition.Methods in rx.subjects with parameters of type Action0 Modifier and Type Method Description static <T> UnicastSubject<T>
UnicastSubject. create(int capacityHint, Action0 onTerminated)
Constructs an empty UnicastSubject instance with a capacity hint and an Action0 instance to call if the subject reaches its terminal state or the single Subscriber unsubscribes mid-sequence.Constructors in rx.subjects with parameters of type Action0 Constructor Description State(int capacityHint, Action0 onTerminated)
Constructor. -
Uses of Action0 in rx.subscriptions
Fields in rx.subscriptions declared as Action0 Modifier and Type Field Description (package private) static Action0
BooleanSubscription. EMPTY_ACTION
Fields in rx.subscriptions with type parameters of type Action0 Modifier and Type Field Description (package private) java.util.concurrent.atomic.AtomicReference<Action0>
BooleanSubscription. actionRef
Methods in rx.subscriptions with parameters of type Action0 Modifier and Type Method Description static BooleanSubscription
BooleanSubscription. create(Action0 onUnsubscribe)
Creates aBooleanSubscription
with a specified function to invoke upon unsubscribe.static Subscription
Subscriptions. create(Action0 unsubscribe)
Creates and returns aSubscription
that invokes the givenAction0
when unsubscribed.Constructors in rx.subscriptions with parameters of type Action0 Constructor Description BooleanSubscription(Action0 action)
-