Uses of Interface
io.reactivex.rxjava3.functions.Action
Packages that use Action
Package
Description
Base reactive classes:
Flowable
, Observable
,
Single
, Maybe
and
Completable
; base reactive consumers;
other common base interfaces.Default implementations for
Disposable
-based resource management
(Disposable
container types) and utility classes to construct
Disposables
from callbacks and other types.Contains the base type
ParallelFlowable
,
a sub-DSL for working with Flowable
sequences in parallel.-
Uses of Action in io.reactivex.rxjava3.core
Methods in io.reactivex.rxjava3.core with parameters of type ActionModifier and TypeMethodDescriptionfinal void
Completable.blockingSubscribe
(@NonNull Action onComplete) Subscribes to the currentCompletable
and calls givenonComplete
callback on the current thread when it completes normally.final void
Completable.blockingSubscribe
(@NonNull Action onComplete, @NonNull Consumer<? super Throwable> onError) Subscribes to the currentCompletable
and calls the appropriate callback on the current thread when it terminates.final void
Flowable.blockingSubscribe
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete) Subscribes to the source and calls the given callbacks on the current thread.final void
Flowable.blockingSubscribe
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete, int bufferSize) Subscribes to the source and calls the given callbacks on the current thread.final void
Maybe.blockingSubscribe
(@NonNull Consumer<? super @NonNull T> onSuccess, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete) Subscribes to the currentMaybe
and calls the appropriate callback on the current thread when it terminates.final void
Observable.blockingSubscribe
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete) Subscribes to the source and calls the given callbacks on the current thread.final @NonNull Completable
Completable.doAfterTerminate
(@NonNull Action onAfterTerminate) Returns aCompletable
instance that calls the givenonAfterTerminate
Action
after thisCompletable
completes normally or with an exception.Flowable.doAfterTerminate
(@NonNull Action onAfterTerminate) Maybe.doAfterTerminate
(@NonNull Action onAfterTerminate) final @NonNull Observable
<T> Observable.doAfterTerminate
(@NonNull Action onAfterTerminate) Single.doAfterTerminate
(@NonNull Action onAfterTerminate) final @NonNull Completable
Calls the specifiedAction
after thisCompletable
signalsonError
oronComplete
or gets disposed by the downstream.Calls the specified action after thisFlowable
signalsonError
oronComplete
or gets canceled by the downstream.Calls the specified action after thisMaybe
signalsonSuccess
,onError
oronComplete
or gets disposed by the downstream.final @NonNull Observable
<T> Calls the specified action after the currentObservable
signalsonError
oronCompleted
or gets disposed by the downstream.Calls the specified action after thisSingle
signalsonSuccess
oronError
or gets disposed by the downstream.Flowable.doOnCancel
(@NonNull Action onCancel) Calls the cancelAction
if the downstream cancels the sequence.final @NonNull Completable
Completable.doOnComplete
(@NonNull Action onComplete) Flowable.doOnComplete
(@NonNull Action onComplete) Maybe.doOnComplete
(@NonNull Action onComplete) final @NonNull Observable
<T> Observable.doOnComplete
(@NonNull Action onComplete) final @NonNull Completable
Completable.doOnDispose
(@NonNull Action onDispose) Calls the sharedAction
if aCompletableObserver
subscribed to the currentCompletable
disposes the commonDisposable
it received viaonSubscribe
.Maybe.doOnDispose
(@NonNull Action onDispose) Calls the sharedAction
if aMaybeObserver
subscribed to the currentMaybe
disposes the commonDisposable
it received viaonSubscribe
.final @NonNull Observable
<T> Observable.doOnDispose
(@NonNull Action onDispose) Calls the given sharedAction
if the downstream disposes the sequence.Single.doOnDispose
(@NonNull Action onDispose) Calls the sharedAction
if aSingleObserver
subscribed to the currentSingle
disposes the commonDisposable
it received viaonSubscribe
.Flowable.doOnEach
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, Action onComplete, Action onAfterTerminate) Calls the appropriate onXXX consumer (shared between all subscribers) whenever a signal with the same type passes through, before forwarding them to downstream.private @NonNull Observable
<T> Observable.doOnEach
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete, @NonNull Action onAfterTerminate) Calls the appropriateonXXX
consumer (shared between allObserver
s) whenever a signal with the same type passes through, before forwarding them to the downstream.final @NonNull Completable
Completable.doOnLifecycle
(@NonNull Consumer<? super Disposable> onSubscribe, @NonNull Action onDispose) Calls the appropriateonXXX
method (shared between allCompletableObserver
s) for the lifecycle events of the sequence (subscription, disposal).private @NonNull Completable
Completable.doOnLifecycle
(Consumer<? super Disposable> onSubscribe, Consumer<? super Throwable> onError, Action onComplete, Action onTerminate, Action onAfterTerminate, Action onDispose) Returns aCompletable
instance that calls the various callbacks upon the specific lifecycle events.Flowable.doOnLifecycle
(@NonNull Consumer<? super org.reactivestreams.Subscription> onSubscribe, @NonNull LongConsumer onRequest, @NonNull Action onCancel) Calls the appropriateonXXX
method (shared between allSubscriber
s) for the lifecycle events of the sequence (subscription, cancellation, requesting).Maybe.doOnLifecycle
(@NonNull Consumer<? super Disposable> onSubscribe, @NonNull Action onDispose) Calls the appropriateonXXX
method (shared between allMaybeObserver
s) for the lifecycle events of the sequence (subscription, disposal).final @NonNull Observable
<T> Observable.doOnLifecycle
(@NonNull Consumer<? super Disposable> onSubscribe, @NonNull Action onDispose) Calls the appropriateonXXX
method (shared between allObserver
s) for the lifecycle events of the sequence (subscription, disposal).Single.doOnLifecycle
(@NonNull Consumer<? super Disposable> onSubscribe, @NonNull Action onDispose) Calls the appropriateonXXX
method (shared between allSingleObserver
s) for the lifecycle events of the sequence (subscription, disposal).final @NonNull Completable
Completable.doOnTerminate
(@NonNull Action onTerminate) Returns aCompletable
instance that calls the givenonTerminate
Action
just before thisCompletable
completes normally or with an exception.Flowable.doOnTerminate
(@NonNull Action onTerminate) Calls the givenAction
when the currentFlowable
completes normally or with an error before those signals are forwarded to the downstream.Maybe.doOnTerminate
(@NonNull Action onTerminate) Returns aMaybe
instance that calls the given onTerminate callback just before thisMaybe
completes normally or with an exception.final @NonNull Observable
<T> Observable.doOnTerminate
(@NonNull Action onTerminate) Returns anObservable
so that it invokes an action when the currentObservable
callsonComplete
oronError
.Single.doOnTerminate
(@NonNull Action onTerminate) Returns aSingle
instance that calls the givenonTerminate
callback just before thisSingle
completes normally or with an exception.final @NonNull Disposable
Flowable.forEachWhile
(@NonNull Predicate<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete) Subscribes to the currentFlowable
and receives notifications for each element and the terminal events until theonNext
Predicate returnsfalse
.final @NonNull Disposable
Observable.forEachWhile
(@NonNull Predicate<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete) Subscribes to theObservableSource
and calls aPredicate
for each item, aConsumer
with the error or anAction
upon completion of the currentObservable
, on their original emission threads, until the predicate returnsfalse
.static @NonNull Completable
Completable.fromAction
(@NonNull Action action) Returns aCompletable
instance that runs the givenAction
for eachCompletableObserver
and emits either an exception or simply completes.Flowable.fromAction
(@NonNull Action action) Returns aFlowable
instance that runs the givenAction
for eachSubscriber
and emits either its exception or simply completes.Maybe.fromAction
(@NonNull Action action) Returns aMaybe
instance that runs the givenAction
for eachMaybeObserver
and emits either its exception or simply completes.static <@NonNull T>
@NonNull Observable<T> Observable.fromAction
(@NonNull Action action) Flowable.onBackpressureBuffer
(int capacity, boolean delayError, boolean unbounded, @NonNull Action onOverflow) Buffers an optionally unlimited number of items from the currentFlowable
and allows it to emit as fast it can while allowing the downstream to consume the items at its own place.Flowable.onBackpressureBuffer
(int capacity, boolean delayError, boolean unbounded, @NonNull Action onOverflow, @NonNull Consumer<? super @NonNull T> onDropped) Buffers an optionally unlimited number of items from the currentFlowable
and allows it to emit as fast it can while allowing the downstream to consume the items at its own place.Flowable.onBackpressureBuffer
(int capacity, @NonNull Action onOverflow) Buffers an limited number of items from the currentFlowable
and allows it to emit as fast it can while allowing the downstream to consume the items at its own place, however, the resultingFlowable
will signal aMissingBackpressureException
viaonError
as soon as the buffer's capacity is exceeded, dropping all undelivered items, canceling the flow and calling theonOverflow
action.Flowable.onBackpressureBuffer
(long capacity, @Nullable Action onOverflow, @NonNull BackpressureOverflowStrategy overflowStrategy) Buffers an optionally unlimited number of items from the currentFlowable
and allows it to emit as fast it can while allowing the downstream to consume the items at its own place.Flowable.onBackpressureBuffer
(long capacity, @Nullable Action onOverflow, @NonNull BackpressureOverflowStrategy overflowStrategy, @NonNull Consumer<? super @NonNull T> onDropped) Buffers an optionally unlimited number of items from the currentFlowable
and allows it to emit as fast it can while allowing the downstream to consume the items at its own place.final @NonNull Disposable
final @NonNull Disposable
Subscribes to thisCompletable
and calls back either theonError
oronComplete
functions.final @NonNull Disposable
Completable.subscribe
(@NonNull Action onComplete, @NonNull Consumer<? super Throwable> onError, @NonNull DisposableContainer container) Wraps the given onXXX callbacks into aDisposable
CompletableObserver
, adds it to the givenDisposableContainer
and ensures, that if the upstream terminates or this particularDisposable
is disposed, theCompletableObserver
is removed from the given composite.final @NonNull Disposable
Flowable.subscribe
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete) Subscribes to the currentFlowable
and provides callbacks to handle the items it emits and any error or completion notification it issues.final @NonNull Disposable
Flowable.subscribe
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete, @NonNull DisposableContainer container) Wraps the given onXXX callbacks into aDisposable
Subscriber
, adds it to the givenDisposableContainer
and ensures, that if the upstream terminates or this particularDisposable
is disposed, theSubscriber
is removed from the given container.final @NonNull Disposable
Maybe.subscribe
(@NonNull Consumer<? super @NonNull T> onSuccess, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete) Subscribes to aMaybe
and provides callbacks to handle the items it emits and any error or completion notification it issues.final @NonNull Disposable
Maybe.subscribe
(@NonNull Consumer<? super @NonNull T> onSuccess, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete, @NonNull DisposableContainer container) Wraps the given onXXX callbacks into aDisposable
MaybeObserver
, adds it to the givenDisposableContainer
and ensures, that if the upstream terminates or this particularDisposable
is disposed, theMaybeObserver
is removed from the given composite.final @NonNull Disposable
Observable.subscribe
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete) Subscribes to the currentObservable
and provides callbacks to handle the items it emits and any error or completion notification it signals.final @NonNull Disposable
Observable.subscribe
(@NonNull Consumer<? super @NonNull T> onNext, @NonNull Consumer<? super Throwable> onError, @NonNull Action onComplete, @NonNull DisposableContainer container) Wraps the given onXXX callbacks into aDisposable
Observer
, adds it to the givenDisposableContainer
and ensures, that if the upstream terminates or this particularDisposable
is disposed, theObserver
is removed from the given container. -
Uses of Action in io.reactivex.rxjava3.disposables
Methods in io.reactivex.rxjava3.disposables with parameters of type ActionModifier and TypeMethodDescriptionstatic @NonNull Disposable
Disposable.fromAction
(@NonNull Action action) Construct aDisposable
by wrapping aAction
that is executed exactly once when theDisposable
is disposed.protected void
ActionDisposable.onDisposed
(@NonNull Action value) Constructors in io.reactivex.rxjava3.disposables with parameters of type Action -
Uses of Action in io.reactivex.rxjava3.internal.functions
Classes in io.reactivex.rxjava3.internal.functions that implement ActionModifier and TypeClassDescription(package private) static final class
(package private) static final class
(package private) static final class
Fields in io.reactivex.rxjava3.internal.functions declared as ActionModifier and TypeFieldDescription(package private) final Action
Functions.ActionConsumer.action
static final Action
Functions.EMPTY_ACTION
Methods in io.reactivex.rxjava3.internal.functions that return ActionModifier and TypeMethodDescriptionFunctions.futureAction
(@NonNull Future<?> future) Wraps the blocking get call of the Future into an Action.static <T> Action
Functions.notificationOnComplete
(Consumer<? super Notification<T>> onNotification) Methods in io.reactivex.rxjava3.internal.functions with parameters of type ActionConstructors in io.reactivex.rxjava3.internal.functions with parameters of type Action -
Uses of Action in io.reactivex.rxjava3.internal.observers
Fields in io.reactivex.rxjava3.internal.observers declared as ActionModifier and TypeFieldDescription(package private) final Action
AbstractDisposableAutoRelease.onComplete
(package private) final Action
CallbackCompletableObserver.onComplete
(package private) final Action
ForEachWhileObserver.onComplete
(package private) final Action
LambdaObserver.onComplete
(package private) final Action
DisposableLambdaObserver.onDispose
Methods in io.reactivex.rxjava3.internal.observers with parameters of type ActionModifier and TypeMethodDescriptionvoid
BlockingMultiObserver.blockingConsume
(Consumer<? super T> onSuccess, Consumer<? super Throwable> onError, Action onComplete) Blocks until the source completes and calls the appropriate callback.Constructors in io.reactivex.rxjava3.internal.observers with parameters of type ActionModifierConstructorDescription(package private)
AbstractDisposableAutoRelease
(DisposableContainer composite, Consumer<? super Throwable> onError, Action onComplete) CallbackCompletableObserver
(Consumer<? super Throwable> onError, Action onComplete) DisposableAutoReleaseMultiObserver
(DisposableContainer composite, Consumer<? super T> onSuccess, Consumer<? super Throwable> onError, Action onComplete) DisposableAutoReleaseObserver
(DisposableContainer composite, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete) DisposableLambdaObserver
(Observer<? super T> actual, Consumer<? super Disposable> onSubscribe, Action onDispose) ForEachWhileObserver
(Predicate<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete) LambdaObserver
(Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, Consumer<? super Disposable> onSubscribe) -
Uses of Action in io.reactivex.rxjava3.internal.operators.completable
Fields in io.reactivex.rxjava3.internal.operators.completable declared as ActionModifier and TypeFieldDescription(package private) final Action
CompletablePeek.onAfterTerminate
(package private) final Action
CompletablePeek.onComplete
(package private) final Action
CompletablePeek.onDispose
(package private) final Action
CompletableDoFinally.DoFinallyObserver.onFinally
(package private) final Action
CompletableDoFinally.onFinally
(package private) final Action
CompletablePeek.onTerminate
(package private) final Action
CompletableFromAction.run
Constructors in io.reactivex.rxjava3.internal.operators.completable with parameters of type ActionModifierConstructorDescriptionCompletableDoFinally
(CompletableSource source, Action onFinally) CompletablePeek
(CompletableSource source, Consumer<? super Disposable> onSubscribe, Consumer<? super Throwable> onError, Action onComplete, Action onTerminate, Action onAfterTerminate, Action onDispose) (package private)
DoFinallyObserver
(CompletableObserver actual, Action onFinally) -
Uses of Action in io.reactivex.rxjava3.internal.operators.flowable
Classes in io.reactivex.rxjava3.internal.operators.flowable that implement ActionModifier and TypeClassDescription(package private) static final class
Fields in io.reactivex.rxjava3.internal.operators.flowable declared as ActionModifier and TypeFieldDescription(package private) final Action
FlowableFromAction.action
(package private) final Action
FlowableDoOnEach.DoOnEachConditionalSubscriber.onAfterTerminate
(package private) final Action
FlowableDoOnEach.DoOnEachSubscriber.onAfterTerminate
(package private) final Action
FlowableDoOnEach.onAfterTerminate
private final Action
FlowableDoOnLifecycle.onCancel
(package private) final Action
FlowableDoOnLifecycle.SubscriptionLambdaSubscriber.onCancel
(package private) final Action
FlowableDoOnEach.DoOnEachConditionalSubscriber.onComplete
(package private) final Action
FlowableDoOnEach.DoOnEachSubscriber.onComplete
(package private) final Action
FlowableDoOnEach.onComplete
(package private) final Action
FlowableDoFinally.DoFinallyConditionalSubscriber.onFinally
(package private) final Action
FlowableDoFinally.DoFinallySubscriber.onFinally
(package private) final Action
FlowableDoFinally.onFinally
(package private) final Action
FlowableOnBackpressureBuffer.BackpressureBufferSubscriber.onOverflow
(package private) final Action
FlowableOnBackpressureBuffer.onOverflow
(package private) final Action
FlowableOnBackpressureBufferStrategy.OnBackpressureBufferStrategySubscriber.onOverflow
(package private) final Action
FlowableOnBackpressureBufferStrategy.onOverflow
Methods in io.reactivex.rxjava3.internal.operators.flowable that return ActionModifier and TypeMethodDescriptionstatic <T> Action
FlowableInternalHelper.subscriberOnComplete
(org.reactivestreams.Subscriber<T> subscriber) Methods in io.reactivex.rxjava3.internal.operators.flowable with parameters of type ActionModifier and TypeMethodDescriptionstatic <T> void
FlowableBlockingSubscribe.subscribe
(org.reactivestreams.Publisher<? extends T> o, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete) Subscribes to the source and calls the given actions on the current thread.static <T> void
FlowableBlockingSubscribe.subscribe
(org.reactivestreams.Publisher<? extends T> o, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, int bufferSize) Subscribes to the source and calls the given actions on the current thread.Constructors in io.reactivex.rxjava3.internal.operators.flowable with parameters of type ActionModifierConstructorDescription(package private)
BackpressureBufferSubscriber
(org.reactivestreams.Subscriber<? super T> actual, int bufferSize, boolean unbounded, boolean delayError, Action onOverflow, Consumer<? super T> onDropped) (package private)
DoFinallyConditionalSubscriber
(ConditionalSubscriber<? super T> actual, Action onFinally) (package private)
DoFinallySubscriber
(org.reactivestreams.Subscriber<? super T> actual, Action onFinally) (package private)
DoOnEachConditionalSubscriber
(ConditionalSubscriber<? super T> actual, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, Action onAfterTerminate) (package private)
DoOnEachSubscriber
(org.reactivestreams.Subscriber<? super T> actual, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, Action onAfterTerminate) FlowableDoFinally
(Flowable<T> source, Action onFinally) FlowableDoOnEach
(Flowable<T> source, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, Action onAfterTerminate) FlowableDoOnLifecycle
(Flowable<T> source, Consumer<? super org.reactivestreams.Subscription> onSubscribe, LongConsumer onRequest, Action onCancel) FlowableFromAction
(Action action) FlowableOnBackpressureBuffer
(Flowable<T> source, int bufferSize, boolean unbounded, boolean delayError, Action onOverflow, Consumer<? super T> onDropped) FlowableOnBackpressureBufferStrategy
(Flowable<T> source, long bufferSize, Action onOverflow, BackpressureOverflowStrategy strategy, Consumer<? super T> onDropped) (package private)
OnBackpressureBufferStrategySubscriber
(org.reactivestreams.Subscriber<? super T> actual, Action onOverflow, BackpressureOverflowStrategy strategy, long bufferSize, Consumer<? super T> onDropped) (package private)
SubscriptionLambdaSubscriber
(org.reactivestreams.Subscriber<? super T> actual, Consumer<? super org.reactivestreams.Subscription> onSubscribe, LongConsumer onRequest, Action onCancel) -
Uses of Action in io.reactivex.rxjava3.internal.operators.maybe
Fields in io.reactivex.rxjava3.internal.operators.maybe declared as ActionModifier and TypeFieldDescription(package private) final Action
MaybeFromAction.action
(package private) final Action
MaybePeek.onAfterTerminate
(package private) final Action
MaybeCallbackObserver.onComplete
(package private) final Action
MaybePeek.onCompleteCall
(package private) final Action
MaybeDoOnLifecycle.MaybeLifecycleObserver.onDispose
(package private) final Action
MaybeDoOnLifecycle.onDispose
(package private) final Action
MaybePeek.onDisposeCall
(package private) final Action
MaybeDoFinally.DoFinallyObserver.onFinally
(package private) final Action
MaybeDoFinally.onFinally
(package private) final Action
MaybeDoOnTerminate.onTerminate
Constructors in io.reactivex.rxjava3.internal.operators.maybe with parameters of type ActionModifierConstructorDescription(package private)
DoFinallyObserver
(MaybeObserver<? super T> actual, Action onFinally) MaybeCallbackObserver
(Consumer<? super T> onSuccess, Consumer<? super Throwable> onError, Action onComplete) MaybeDoFinally
(MaybeSource<T> source, Action onFinally) MaybeDoOnLifecycle
(Maybe<T> upstream, Consumer<? super Disposable> onSubscribe, Action onDispose) MaybeDoOnTerminate
(MaybeSource<T> source, Action onTerminate) MaybeFromAction
(Action action) (package private)
MaybeLifecycleObserver
(MaybeObserver<? super T> downstream, Consumer<? super Disposable> onSubscribe, Action onDispose) MaybePeek
(MaybeSource<T> source, Consumer<? super Disposable> onSubscribeCall, Consumer<? super T> onSuccessCall, Consumer<? super Throwable> onErrorCall, Action onCompleteCall, Action onAfterTerminate, Action onDispose) -
Uses of Action in io.reactivex.rxjava3.internal.operators.observable
Classes in io.reactivex.rxjava3.internal.operators.observable that implement ActionModifier and TypeClassDescription(package private) static final class
Fields in io.reactivex.rxjava3.internal.operators.observable declared as ActionModifier and TypeFieldDescription(package private) final Action
ObservableFromAction.action
(package private) final Action
ObservableDoOnEach.DoOnEachObserver.onAfterTerminate
(package private) final Action
ObservableDoOnEach.onAfterTerminate
(package private) final Action
ObservableDoOnEach.DoOnEachObserver.onComplete
(package private) final Action
ObservableDoOnEach.onComplete
private final Action
ObservableDoOnLifecycle.onDispose
(package private) final Action
ObservableDoFinally.DoFinallyObserver.onFinally
(package private) final Action
ObservableDoFinally.onFinally
Methods in io.reactivex.rxjava3.internal.operators.observable that return ActionModifier and TypeMethodDescriptionstatic <T> Action
ObservableInternalHelper.observerOnComplete
(Observer<T> observer) Methods in io.reactivex.rxjava3.internal.operators.observable with parameters of type ActionModifier and TypeMethodDescriptionstatic <T> void
ObservableBlockingSubscribe.subscribe
(ObservableSource<? extends T> o, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete) Subscribes to the source and calls the given actions on the current thread.Constructors in io.reactivex.rxjava3.internal.operators.observable with parameters of type ActionModifierConstructorDescription(package private)
DoFinallyObserver
(Observer<? super T> actual, Action onFinally) (package private)
DoOnEachObserver
(Observer<? super T> actual, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, Action onAfterTerminate) ObservableDoFinally
(ObservableSource<T> source, Action onFinally) ObservableDoOnEach
(ObservableSource<T> source, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, Action onAfterTerminate) ObservableDoOnLifecycle
(Observable<T> upstream, Consumer<? super Disposable> onSubscribe, Action onDispose) ObservableFromAction
(Action action) -
Uses of Action in io.reactivex.rxjava3.internal.operators.parallel
Fields in io.reactivex.rxjava3.internal.operators.parallel declared as ActionModifier and TypeFieldDescription(package private) final Action
ParallelPeek.onAfterTerminated
(package private) final Action
ParallelPeek.onCancel
(package private) final Action
ParallelPeek.onComplete
Constructors in io.reactivex.rxjava3.internal.operators.parallel with parameters of type ActionModifierConstructorDescriptionParallelPeek
(ParallelFlowable<T> source, Consumer<? super T> onNext, Consumer<? super T> onAfterNext, Consumer<? super Throwable> onError, Action onComplete, Action onAfterTerminated, Consumer<? super org.reactivestreams.Subscription> onSubscribe, LongConsumer onRequest, Action onCancel) -
Uses of Action in io.reactivex.rxjava3.internal.operators.single
Fields in io.reactivex.rxjava3.internal.operators.single declared as ActionModifier and TypeFieldDescription(package private) final Action
SingleDoAfterTerminate.DoAfterTerminateObserver.onAfterTerminate
(package private) final Action
SingleDoAfterTerminate.onAfterTerminate
(package private) final Action
SingleDoOnDispose.onDispose
(package private) final Action
SingleDoOnLifecycle.onDispose
(package private) final Action
SingleDoOnLifecycle.SingleLifecycleObserver.onDispose
(package private) final Action
SingleDoFinally.DoFinallyObserver.onFinally
(package private) final Action
SingleDoFinally.onFinally
(package private) final Action
SingleDoOnTerminate.onTerminate
Constructors in io.reactivex.rxjava3.internal.operators.single with parameters of type ActionModifierConstructorDescription(package private)
DoAfterTerminateObserver
(SingleObserver<? super T> actual, Action onAfterTerminate) (package private)
DoFinallyObserver
(SingleObserver<? super T> actual, Action onFinally) (package private)
DoOnDisposeObserver
(SingleObserver<? super T> actual, Action onDispose) SingleDoAfterTerminate
(SingleSource<T> source, Action onAfterTerminate) SingleDoFinally
(SingleSource<T> source, Action onFinally) SingleDoOnDispose
(SingleSource<T> source, Action onDispose) SingleDoOnLifecycle
(Single<T> upstream, Consumer<? super Disposable> onSubscribe, Action onDispose) SingleDoOnTerminate
(SingleSource<T> source, Action onTerminate) (package private)
SingleLifecycleObserver
(SingleObserver<? super T> downstream, Consumer<? super Disposable> onSubscribe, Action onDispose) -
Uses of Action in io.reactivex.rxjava3.internal.subscribers
Fields in io.reactivex.rxjava3.internal.subscribers declared as ActionModifier and TypeFieldDescription(package private) final Action
BoundedSubscriber.onComplete
(package private) final Action
DisposableAutoReleaseSubscriber.onComplete
(package private) final Action
ForEachWhileSubscriber.onComplete
(package private) final Action
LambdaSubscriber.onComplete
Constructors in io.reactivex.rxjava3.internal.subscribers with parameters of type ActionModifierConstructorDescriptionBoundedSubscriber
(Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, Consumer<? super org.reactivestreams.Subscription> onSubscribe, int bufferSize) DisposableAutoReleaseSubscriber
(DisposableContainer composite, Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete) ForEachWhileSubscriber
(Predicate<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete) LambdaSubscriber
(Consumer<? super T> onNext, Consumer<? super Throwable> onError, Action onComplete, Consumer<? super org.reactivestreams.Subscription> onSubscribe) -
Uses of Action in io.reactivex.rxjava3.internal.util
Classes in io.reactivex.rxjava3.internal.util that implement ActionModifier and TypeClassDescriptionfinal class
Stores an incoming Throwable (if any) and counts itself down. -
Uses of Action in io.reactivex.rxjava3.parallel
Methods in io.reactivex.rxjava3.parallel with parameters of type ActionModifier and TypeMethodDescriptionfinal @NonNull ParallelFlowable
<T> ParallelFlowable.doAfterTerminated
(@NonNull Action onAfterTerminate) Run the specifiedAction
when a 'rail' completes or signals an error.final @NonNull ParallelFlowable
<T> ParallelFlowable.doOnCancel
(@NonNull Action onCancel) Run the specifiedAction
when a 'rail' receives a cancellation.final @NonNull ParallelFlowable
<T> ParallelFlowable.doOnComplete
(@NonNull Action onComplete) Run the specifiedAction
when a 'rail' completes.