Uses of Class
rx.Completable
Packages that use Completable
Package
Description
Base reactive classes: Observable, Single and Completable; base reactive consumers;
other common base interfaces.
Operators that allow composing Observables to transform and
manipulate data in an asynchronous, functional and thread-safe manner.
Callback types and a central plugin handler class to hook into the lifecycle
of the base reactive types and schedulers.
-
Uses of Completable in rx
Fields in rx declared as CompletableModifier and TypeFieldDescription(package private) static final Completable
Completable.COMPLETE
Single instance of a complete Completable.(package private) static final Completable
Completable.NEVER
Single instance of a never Completable.Methods in rx that return CompletableModifier and TypeMethodDescriptionstatic Completable
Completable.amb
(Iterable<? extends Completable> sources) Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.static Completable
Completable.amb
(Completable... sources) Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.final Completable
Completable.ambWith
(Completable other) Returns a Completable that emits the a terminated event of either this Completable or the other Completable whichever fires first.final Completable
Completable.andThen
(Completable next) Returns a completable that first runs this Completable and then the other completable.static Completable
Completable.complete()
Returns a Completable instance that completes immediately when subscribed to.final Completable
Completable.compose
(Completable.CompletableTransformer transformer) Calls the given transformer function with this instance and returns the function's resulting Completable.static Completable
Completable.concat
(Iterable<? extends Completable> sources) Returns a Completable which completes only when all sources complete, one after another.static Completable
Completable.concat
(Completable... sources) Returns a Completable which completes only when all sources complete, one after another.static Completable
Completable.concat
(Observable<? extends Completable> sources) Returns a Completable which completes only when all sources complete, one after another.static Completable
Completable.concat
(Observable<? extends Completable> sources, int prefetch) Returns a Completable which completes only when all sources complete, one after another.final Completable
Completable.concatWith
(Completable other) Concatenates this Completable with another Completable.static Completable
Completable.create
(Completable.CompletableOnSubscribe onSubscribe) Constructs a Completable instance by wrapping the given onSubscribe callback.static Completable
Completable.defer
(Func0<? extends Completable> completableFunc0) Defers the subscription to a Completable instance returned by a supplier.final Completable
Returns a Completable which delays the emission of the completion event by the given time.final Completable
Returns a Completable which delays the emission of the completion event by the given time while running on the specified scheduler.final Completable
Returns a Completable which delays the emission of the completion event, and optionally the error as well, by the given time while running on the specified scheduler.final Completable
Completable.doAfterTerminate
(Action0 onAfterComplete) Returns a Completable instance that calls the given onAfterComplete callback after this Completable completes normally.final Completable
Completable.doOnComplete
(Action0 onComplete) Deprecated.final Completable
Completable.doOnCompleted
(Action0 onCompleted) Returns a Completable which calls the given onCompleted callback if this Completable completes.final Completable
Returns a Completable which calls the given onError callback if this Completable emits an error.protected final Completable
Completable.doOnLifecycle
(Action1<? super Subscription> onSubscribe, Action1<? super Throwable> onError, Action0 onComplete, Action0 onAfterComplete, Action0 onUnsubscribe) Returns a Completable instance that calls the various callbacks on the specific lifecycle events.final Completable
Completable.doOnSubscribe
(Action1<? super Subscription> onSubscribe) Returns a Completable instance that calls the given onSubscribe callback with the disposable that child subscribers receive on subscription.final Completable
Completable.doOnTerminate
(Action0 onTerminate) Returns a Completable instance that calls the given onTerminate callback just before this Completable completes normally or with an exceptionfinal Completable
Completable.doOnUnsubscribe
(Action0 onUnsubscribe) Returns a Completable which calls the given onUnsubscribe callback if the child subscriber cancels the subscription.final Completable
Completable.endWith
(Completable other) Deprecated.UseandThen(rx.Completable)
instead.static Completable
Creates a Completable instance that emits the given Throwable exception to subscribers.static Completable
Creates a Completable which calls the given error supplier for each subscriber and emits its returned Throwable.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.static Completable
Completable.fromCallable
(Callable<?> callable) Returns a Completable which when subscribed, executes the callable function, ignores its normal result and emits onError or onCompleted only.static Completable
Completable.fromFuture
(Future<?> future) Returns a Completable instance that reacts to the termination of the given Future in a blocking fashion.static Completable
Completable.fromObservable
(Observable<?> flowable) Returns a Completable instance that subscribes to the given flowable, ignores all values and emits only the terminal event.static Completable
Completable.fromSingle
(Single<?> single) Returns a Completable instance that when subscribed to, subscribes to the Single instance and emits a completion event if the single emits onSuccess or forwards any onError events.final Completable
Completable.lift
(Completable.CompletableOperator onLift) Lifts a CompletableSubscriber transformation into the chain of Completables.static Completable
Completable.merge
(Iterable<? extends Completable> sources) Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.static Completable
Completable.merge
(Completable... sources) Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.static Completable
Completable.merge
(Observable<? extends Completable> sources) Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.static Completable
Completable.merge
(Observable<? extends Completable> sources, int maxConcurrency) Returns a Completable instance that keeps subscriptions to a limited number of sources at once and completes only when all source Completables complete or one of them emits an error.protected static Completable
Completable.merge0
(Observable<? extends Completable> sources, int maxConcurrency, boolean delayErrors) Returns a Completable instance that keeps subscriptions to a limited number of sources at once and completes only when all source Completables terminate in one way or another, combining any exceptions thrown by either the sources Observable or the inner Completable instances.static Completable
Completable.mergeDelayError
(Iterable<? extends Completable> sources) Returns a Completable that subscribes to all Completables in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.static Completable
Completable.mergeDelayError
(Completable... sources) Returns a Completable that subscribes to all Completables in the source array and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.static Completable
Completable.mergeDelayError
(Observable<? extends Completable> sources) Returns a Completable that subscribes to all Completables in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.static Completable
Completable.mergeDelayError
(Observable<? extends Completable> sources, int maxConcurrency) Returns a Completable that subscribes to a limited number of inner Completables at once in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.final Completable
Completable.mergeWith
(Completable other) Returns a Completable which subscribes to this and the other Completable and completes when both of them complete or one emits an error.static Completable
Completable.never()
Returns a Completable that never calls onError or onComplete.final Completable
Returns a Completable which emits the terminal events from the thread of the specified scheduler.final Completable
Completable.onErrorComplete()
Returns a Completable instance that if this Completable emits an error, it will emit an onComplete and swallow the throwable.final Completable
Completable.onErrorComplete
(Func1<? super Throwable, Boolean> predicate) Returns a Completable instance that if this Completable emits an error and the predicate returns true, it will emit an onComplete and swallow the throwable.final Completable
Completable.onErrorResumeNext
(Func1<? super Throwable, ? extends Completable> errorMapper) Returns a Completable instance that when encounters an error from this Completable, calls the specified mapper function that returns another Completable instance for it and resumes the execution with it.final Completable
Completable.repeat()
Returns a Completable that repeatedly subscribes to this Completable until cancelled.final Completable
Completable.repeat
(long times) Returns a Completable that subscribes repeatedly at most the given times to this Completable.final Completable
Completable.repeatWhen
(Func1<? super Observable<? extends Void>, ? extends Observable<?>> handler) Returns a Completable instance that repeats when the Publisher returned by the handler emits an item or completes when this Publisher emits a completed event.final Completable
Completable.retry()
Returns a Completable that retries this Completable as long as it emits an onError event.final Completable
Completable.retry
(long times) Returns a Completable that when this Completable emits an error, retries at most the given number of times before giving up and emitting the last error.final Completable
Returns a Completable that retries this Completable in case of an error as long as the predicate returns true.final Completable
Completable.retryWhen
(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>> handler) Returns a Completable which given a Publisher and when this Completable emits an error, delivers that error through an Observable and the Publisher should return a value indicating a retry in response or a terminal event indicating a termination.final Completable
Completable.startWith
(Completable other) Returns a Completable which first runs the other Completable then this completable if the other completed normally.final Completable
Completable.subscribeOn
(Scheduler scheduler) Returns a Completable which subscribes the child subscriber on the specified scheduler, making sure the subscription side-effects happen on that specific thread of the scheduler.final Completable
Returns a Completable that runs this Completable and emits a TimeoutException in case this Completable doesn't complete within the given time.final Completable
Completable.timeout
(long timeout, TimeUnit unit, Completable other) Returns a Completable that runs this Completable and switches to the other Completable in case this Completable doesn't complete within the given time.final Completable
Returns a Completable that runs this Completable and emits a TimeoutException in case this Completable doesn't complete within the given time while "waiting" on the specified Scheduler.final Completable
Completable.timeout
(long timeout, TimeUnit unit, Scheduler scheduler, Completable other) Returns a Completable that runs this Completable and switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.final Completable
Completable.timeout0
(long timeout, TimeUnit unit, Scheduler scheduler, Completable other) Returns a Completable that runs this Completable and optionally switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.static Completable
Returns a Completable instance that fires its onComplete event after the given delay elapsed.static Completable
Returns a Completable instance that fires its onCompleted event after the given delay elapsed by using the supplied scheduler.Observable.toCompletable()
Returns a Completable that discards all onNext emissions (similar toignoreAllElements()
) and calls onCompleted when this source observable calls onCompleted.final Completable
Single.toCompletable()
Returns aCompletable
that discards result of theSingle
(similar toObservable.ignoreElements()
) and callsonCompleted
when this sourceSingle
callsonSuccess
.final Completable
Completable.unsubscribeOn
(Scheduler scheduler) Returns a Completable which makes sure when a subscriber cancels the subscription, the dispose is called on the specified schedulerstatic <R> Completable
Completable.using
(Func0<R> resourceFunc0, Func1<? super R, ? extends Completable> completableFunc1, Action1<? super R> disposer) Returns a Completable instance which manages a resource along with a custom Completable instance while the subscription is active.static <R> Completable
Completable.using
(Func0<R> resourceFunc0, Func1<? super R, ? extends Completable> completableFunc1, Action1<? super R> disposer, boolean eager) Returns a Completable instance which manages a resource along with a custom Completable instance while the subscription is active and performs eager or lazy resource disposition.Methods in rx with parameters of type CompletableModifier and TypeMethodDescriptionstatic Completable
Completable.amb
(Completable... sources) Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.final Completable
Completable.ambWith
(Completable other) Returns a Completable that emits the a terminated event of either this Completable or the other Completable whichever fires first.final Completable
Completable.andThen
(Completable next) Returns a completable that first runs this Completable and then the other completable.static Completable
Completable.concat
(Completable... sources) Returns a Completable which completes only when all sources complete, one after another.final Completable
Completable.concatWith
(Completable other) Concatenates this Completable with another Completable.final Completable
Completable.endWith
(Completable other) Deprecated.UseandThen(rx.Completable)
instead.static Completable
Completable.merge
(Completable... sources) Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.static Completable
Completable.mergeDelayError
(Completable... sources) Returns a Completable that subscribes to all Completables in the source array and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.final Completable
Completable.mergeWith
(Completable other) Returns a Completable which subscribes to this and the other Completable and completes when both of them complete or one emits an error.final Completable
Completable.startWith
(Completable other) Returns a Completable which first runs the other Completable then this completable if the other completed normally.Single.takeUntil
(Completable other) Returns a Single that emits the item emitted by the source Single until a Completable terminates.final Completable
Completable.timeout
(long timeout, TimeUnit unit, Completable other) Returns a Completable that runs this Completable and switches to the other Completable in case this Completable doesn't complete within the given time.final Completable
Completable.timeout
(long timeout, TimeUnit unit, Scheduler scheduler, Completable other) Returns a Completable that runs this Completable and switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.final Completable
Completable.timeout0
(long timeout, TimeUnit unit, Scheduler scheduler, Completable other) Returns a Completable that runs this Completable and optionally switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.Method parameters in rx with type arguments of type CompletableModifier and TypeMethodDescriptionstatic Completable
Completable.amb
(Iterable<? extends Completable> sources) Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.static Completable
Completable.concat
(Iterable<? extends Completable> sources) Returns a Completable which completes only when all sources complete, one after another.static Completable
Completable.concat
(Observable<? extends Completable> sources) Returns a Completable which completes only when all sources complete, one after another.static Completable
Completable.concat
(Observable<? extends Completable> sources, int prefetch) Returns a Completable which completes only when all sources complete, one after another.static Completable
Completable.defer
(Func0<? extends Completable> completableFunc0) Defers the subscription to a Completable instance returned by a supplier.static Completable
Completable.merge
(Iterable<? extends Completable> sources) Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.static Completable
Completable.merge
(Observable<? extends Completable> sources) Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.static Completable
Completable.merge
(Observable<? extends Completable> sources, int maxConcurrency) Returns a Completable instance that keeps subscriptions to a limited number of sources at once and completes only when all source Completables complete or one of them emits an error.protected static Completable
Completable.merge0
(Observable<? extends Completable> sources, int maxConcurrency, boolean delayErrors) Returns a Completable instance that keeps subscriptions to a limited number of sources at once and completes only when all source Completables terminate in one way or another, combining any exceptions thrown by either the sources Observable or the inner Completable instances.static Completable
Completable.mergeDelayError
(Iterable<? extends Completable> sources) Returns a Completable that subscribes to all Completables in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.static Completable
Completable.mergeDelayError
(Observable<? extends Completable> sources) Returns a Completable that subscribes to all Completables in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.static Completable
Completable.mergeDelayError
(Observable<? extends Completable> sources, int maxConcurrency) Returns a Completable that subscribes to a limited number of inner Completables at once in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.final Completable
Completable.onErrorResumeNext
(Func1<? super Throwable, ? extends Completable> errorMapper) Returns a Completable instance that when encounters an error from this Completable, calls the specified mapper function that returns another Completable instance for it and resumes the execution with it.final <U> U
Completable.to
(Func1<? super Completable, U> converter) Allows fluent conversion to another type via a function callback.static <R> Completable
Completable.using
(Func0<R> resourceFunc0, Func1<? super R, ? extends Completable> completableFunc1, Action1<? super R> disposer) Returns a Completable instance which manages a resource along with a custom Completable instance while the subscription is active.static <R> Completable
Completable.using
(Func0<R> resourceFunc0, Func1<? super R, ? extends Completable> completableFunc1, Action1<? super R> disposer, boolean eager) Returns a Completable instance which manages a resource along with a custom Completable instance while the subscription is active and performs eager or lazy resource disposition.<S extends Scheduler & Subscription>
SScheduler.when
(Func1<Observable<Observable<Completable>>, Completable> combine) Allows the use of operators for controlling the timing around when actions scheduled on workers are actually done.<S extends Scheduler & Subscription>
SScheduler.when
(Func1<Observable<Observable<Completable>>, Completable> combine) Allows the use of operators for controlling the timing around when actions scheduled on workers are actually done. -
Uses of Completable in rx.internal.operators
Fields in rx.internal.operators declared as CompletableModifier and TypeFieldDescription(package private) final Completable
CompletableOnSubscribeTimeout.other
(package private) final Completable
CompletableOnSubscribeTimeout.source
(package private) final Completable[]
CompletableOnSubscribeConcatArray.ConcatInnerSubscriber.sources
(package private) final Completable[]
CompletableOnSubscribeConcatArray.sources
(package private) final Completable[]
CompletableOnSubscribeMergeArray.sources
(package private) final Completable[]
CompletableOnSubscribeMergeDelayErrorArray.sources
Fields in rx.internal.operators with type parameters of type CompletableModifier and TypeFieldDescription(package private) final SpscArrayQueue
<Completable> CompletableOnSubscribeConcat.CompletableConcatSubscriber.queue
(package private) final Observable
<Completable> CompletableOnSubscribeMerge.source
(package private) final Observable
<Completable> CompletableOnSubscribeConcat.sources
(package private) final Iterator
<? extends Completable> CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber.sources
(package private) final Iterable
<? extends Completable> CompletableOnSubscribeConcatIterable.sources
(package private) final Iterable
<? extends Completable> CompletableOnSubscribeMergeDelayErrorIterable.sources
(package private) final Iterable
<? extends Completable> CompletableOnSubscribeMergeIterable.sources
Methods in rx.internal.operators with parameters of type CompletableModifier and TypeMethodDescriptionvoid
CompletableOnSubscribeConcat.CompletableConcatSubscriber.onNext
(Completable t) void
CompletableOnSubscribeMerge.CompletableMergeSubscriber.onNext
(Completable t) Constructors in rx.internal.operators with parameters of type CompletableModifierConstructorDescriptionCompletableOnSubscribeConcatArray
(Completable[] sources) CompletableOnSubscribeMergeArray
(Completable[] sources) CompletableOnSubscribeTimeout
(Completable source, long timeout, TimeUnit unit, Scheduler scheduler, Completable other) ConcatInnerSubscriber
(Completable.CompletableSubscriber actual, Completable[] sources) Constructor parameters in rx.internal.operators with type arguments of type CompletableModifierConstructorDescriptionCompletableOnSubscribeConcat
(Observable<? extends Completable> sources, int prefetch) CompletableOnSubscribeConcatIterable
(Iterable<? extends Completable> sources) CompletableOnSubscribeMerge
(Observable<? extends Completable> source, int maxConcurrency, boolean delayErrors) CompletableOnSubscribeMergeDelayErrorIterable
(Iterable<? extends Completable> sources) CompletableOnSubscribeMergeIterable
(Iterable<? extends Completable> sources) ConcatInnerSubscriber
(Completable.CompletableSubscriber actual, Iterator<? extends Completable> sources) -
Uses of Completable in rx.internal.schedulers
Fields in rx.internal.schedulers with type parameters of type CompletableModifier and TypeFieldDescriptionprivate final Observer
<Observable<Completable>> SchedulerWhen.workerObserver
Constructor parameters in rx.internal.schedulers with type arguments of type CompletableModifierConstructorDescriptionSchedulerWhen
(Func1<Observable<Observable<Completable>>, Completable> combine, Scheduler actualScheduler) SchedulerWhen
(Func1<Observable<Observable<Completable>>, Completable> combine, Scheduler actualScheduler) -
Uses of Completable in rx.plugins
Fields in rx.plugins with type parameters of type CompletableModifier and TypeFieldDescription(package private) static Func2
<Completable, Completable.CompletableOnSubscribe, Completable.CompletableOnSubscribe> RxJavaHooks.onCompletableStart
Methods in rx.plugins that return types with arguments of type CompletableModifier and TypeMethodDescriptionRxJavaHooks.getOnCompletableStart()
Returns the current Completable onStart hook function or null if it is set to the default pass-through.Methods in rx.plugins with parameters of type CompletableModifier and TypeMethodDescriptionstatic <T> Completable.CompletableOnSubscribe
RxJavaHooks.onCompletableStart
(Completable instance, Completable.CompletableOnSubscribe onSubscribe) Hook to call before the child subscriber is subscribed to the OnSubscribe action.RxJavaCompletableExecutionHook.onSubscribeStart
(Completable completableInstance, Completable.CompletableOnSubscribe onSubscribe) Deprecated.Method parameters in rx.plugins with type arguments of type CompletableModifier and TypeMethodDescriptionstatic void
RxJavaHooks.setOnCompletableStart
(Func2<Completable, Completable.CompletableOnSubscribe, Completable.CompletableOnSubscribe> onCompletableStart) Sets the hook function that is called when a subscriber subscribes to a Completable unless a lockdown is in effect.
doOnCompleted(Action0)
instead.