Uses of Interface
io.reactivex.rxjava3.core.CompletableSource
Packages that use CompletableSource
Package
Description
Base reactive classes:
Flowable
, Observable
,
Single
, Maybe
and
Completable
; base reactive consumers;
other common base interfaces.Base interfaces and types for supporting operator-fusion.
Classes representing so-called hot sources, aka subjects, that implement a base reactive class and
the respective consumer type at once to allow forms of multicasting events to multiple
consumers as well as consuming another base reactive type of their kind.
-
Uses of CompletableSource in io.reactivex.rxjava3.core
Classes in io.reactivex.rxjava3.core that implement CompletableSourceModifier and TypeClassDescriptionclass
TheCompletable
class represents a deferred computation without any value but only indication for completion or exception.Methods in io.reactivex.rxjava3.core that return CompletableSourceModifier and TypeMethodDescriptionCompletableTransformer.apply
(@NonNull Completable upstream) Applies a function to the upstreamCompletable
and returns aCompletableSource
.Methods in io.reactivex.rxjava3.core with parameters of type CompletableSourceModifier and TypeMethodDescriptionstatic @NonNull Completable
Completable.ambArray
(@NonNull CompletableSource... sources) Returns aCompletable
which terminates as soon as one of the sourceCompletable
s terminates (normally or with an error) and disposes all otherCompletable
s.final @NonNull Completable
Completable.ambWith
(@NonNull CompletableSource other) Returns aCompletable
that emits the a terminated event of either thisCompletable
or the otherCompletableSource
, whichever fires first.final @NonNull Completable
Completable.andThen
(@NonNull CompletableSource next) static @NonNull Completable
Completable.concatArray
(@NonNull CompletableSource... sources) Returns aCompletable
which completes only when all sources complete, one after another.static @NonNull Completable
Completable.concatArrayDelayError
(@NonNull CompletableSource... sources) Returns aCompletable
which completes only when all sources complete, one after another.final @NonNull Completable
Completable.concatWith
(@NonNull CompletableSource other) Concatenates thisCompletable
with anotherCompletableSource
.Flowable.concatWith
(@NonNull CompletableSource other) Returns aFlowable
that emits items from thisFlowable
and when it completes normally, the otherCompletableSource
is subscribed to and the returnedFlowable
emits its terminal events.final @NonNull Observable
<T> Observable.concatWith
(@NonNull CompletableSource other) Returns anObservable
that emits items from the currentObservable
and when it completes normally, the otherCompletableSource
is subscribed to and the returnedObservable
emits its terminal events.Single.delaySubscription
(@NonNull CompletableSource subscriptionIndicator) Delays the actual subscription to the currentSingle
until the given otherCompletableSource
completes.Flowable.fromCompletable
(@NonNull CompletableSource completableSource) Wraps aCompletableSource
into aFlowable
.Maybe.fromCompletable
(@NonNull CompletableSource completableSource) Wraps aCompletableSource
into aMaybe
.static <@NonNull T>
@NonNull Observable<T> Observable.fromCompletable
(@NonNull CompletableSource completableSource) Wraps aCompletableSource
into anObservable
.static @NonNull Completable
Completable.mergeArray
(@NonNull CompletableSource... sources) Returns aCompletable
instance that subscribes to all sources at once and completes only when all sourceCompletableSource
s complete or one of them emits an error.static @NonNull Completable
Completable.mergeArrayDelayError
(@NonNull CompletableSource... sources) Returns aCompletable
that subscribes to allCompletableSource
s in the source array and delays any error emitted by any of the innerCompletableSource
s until all of them terminate in a way or another.final @NonNull Completable
Completable.mergeWith
(@NonNull CompletableSource other) Returns aCompletable
which subscribes to this and the otherCompletableSource
and completes when both of them complete or one emits an error.Flowable.mergeWith
(@NonNull CompletableSource other) Relays the items of thisFlowable
and completes only when the otherCompletableSource
completes as well.final @NonNull Observable
<T> Observable.mergeWith
(@NonNull CompletableSource other) Relays the items of the currentObservable
and completes only when the otherCompletableSource
completes as well.final @NonNull Completable
Completable.onErrorResumeWith
(@NonNull CompletableSource fallback) Resumes the flow with the givenCompletableSource
when the currentCompletable
fails instead of signaling the error viaonError
.Completable.sequenceEqual
(@NonNull CompletableSource source1, @NonNull CompletableSource source2) final @NonNull Completable
Completable.startWith
(@NonNull CompletableSource other) Returns aCompletable
which first runs the otherCompletableSource
then the currentCompletable
if the other completed normally.Flowable.startWith
(@NonNull CompletableSource other) Returns aFlowable
which first runs the otherCompletableSource
then the currentFlowable
if the other completed normally.Maybe.startWith
(@NonNull CompletableSource other) Returns aFlowable
which first runs the otherCompletableSource
then the currentMaybe
if the other completed normally.final @NonNull Observable
<T> Observable.startWith
(@NonNull CompletableSource other) Returns anObservable
which first runs the otherCompletableSource
then the currentObservable
if the other completed normally.Single.startWith
(@NonNull CompletableSource other) Returns aFlowable
which first runs the otherCompletableSource
then the currentSingle
if the other completed normally.final @NonNull Completable
Completable.takeUntil
(@NonNull CompletableSource other) Terminates the downstream if this or the otherCompletable
terminates (wins the termination race) while disposing the connection to the losing source.Single.takeUntil
(@NonNull CompletableSource other) Returns aSingle
that emits the item emitted by the currentSingle
until aCompletableSource
terminates.final @NonNull Completable
Completable.timeout
(long timeout, @NonNull TimeUnit unit, @NonNull CompletableSource fallback) Returns aCompletable
that runs thisCompletable
and switches to the otherCompletableSource
in case thisCompletable
doesn't complete within the given time.final @NonNull Completable
Completable.timeout
(long timeout, @NonNull TimeUnit unit, @NonNull Scheduler scheduler, @NonNull CompletableSource fallback) Returns aCompletable
that runs thisCompletable
and switches to the otherCompletableSource
in case thisCompletable
doesn't complete within the given time while "waiting" on the specifiedScheduler
.private @NonNull Completable
Completable.timeout0
(long timeout, TimeUnit unit, Scheduler scheduler, CompletableSource fallback) Returns aCompletable
that runs thisCompletable
and optionally switches to the otherCompletableSource
in case thisCompletable
doesn't complete within the given time while "waiting" on the specifiedScheduler
.static @NonNull Completable
Completable.unsafeCreate
(@NonNull CompletableSource onSubscribe) Constructs aCompletable
instance by wrapping the given source callback without any safeguards; you should manage the lifecycle and response to downstream disposal.static @NonNull Completable
Completable.wrap
(@NonNull CompletableSource source) Method parameters in io.reactivex.rxjava3.core with type arguments of type CompletableSourceModifier and TypeMethodDescriptionstatic @NonNull Completable
Completable.amb
(@NonNull Iterable<@NonNull ? extends CompletableSource> sources) Returns aCompletable
which terminates as soon as one of the sourceCompletable
s in theIterable
sequence terminates (normally or with an error) and disposes all otherCompletable
s.static @NonNull Completable
Completable.concat
(@NonNull Iterable<@NonNull ? extends CompletableSource> sources) Returns aCompletable
which completes only when all sources complete, one after another.static @NonNull Completable
Completable.concat
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources) Returns aCompletable
which completes only when all sources complete, one after another.static @NonNull Completable
Completable.concat
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources, int prefetch) Returns aCompletable
which completes only when all sources complete, one after another.static @NonNull Completable
Completable.concatDelayError
(@NonNull Iterable<@NonNull ? extends CompletableSource> sources) Returns aCompletable
which completes only when all sources complete, one after another.static @NonNull Completable
Completable.concatDelayError
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources) Returns aCompletable
which completes only when all sources complete, one after another.static @NonNull Completable
Completable.concatDelayError
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources, int prefetch) Returns aCompletable
which completes only when all sources complete, one after another.final @NonNull Completable
Flowable.concatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps the upstream items intoCompletableSource
s and subscribes to them one after the other completes.final @NonNull Completable
Flowable.concatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper, int prefetch) Maps the upstream items intoCompletableSource
s and subscribes to them one after the other completes.final @NonNull Completable
Maybe.concatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Returns aCompletable
that completes based on applying a specified function to the item emitted by the currentMaybe
, where that function returns aCompletable
.final @NonNull Completable
Observable.concatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps each element of the currentObservable
intoCompletableSource
s, subscribes to them one at a time in order and waits until the upstream and allCompletableSource
s complete.final @NonNull Completable
Observable.concatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper, int capacityHint) Maps each element of the currentObservable
intoCompletableSource
s, subscribes to them one at a time in order and waits until the upstream and allCompletableSource
s complete.final @NonNull Completable
Single.concatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Returns aCompletable
that completes based on applying a specified function to the item emitted by the currentSingle
, where that function returns aCompletableSource
.final @NonNull Completable
Flowable.concatMapCompletableDelayError
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps the upstream items intoCompletableSource
s and subscribes to them one after the other terminates, delaying all errors till both thisFlowable
and all innerCompletableSource
s terminate.final @NonNull Completable
Flowable.concatMapCompletableDelayError
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper, boolean tillTheEnd) Maps the upstream items intoCompletableSource
s and subscribes to them one after the other terminates, optionally delaying all errors till both thisFlowable
and all innerCompletableSource
s terminate.final @NonNull Completable
Flowable.concatMapCompletableDelayError
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper, boolean tillTheEnd, int prefetch) Maps the upstream items intoCompletableSource
s and subscribes to them one after the other terminates, optionally delaying all errors till both thisFlowable
and all innerCompletableSource
s terminate.final @NonNull Completable
Observable.concatMapCompletableDelayError
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps the upstream items intoCompletableSource
s and subscribes to them one after the other terminates, delaying all errors till both the currentObservable
and all innerCompletableSource
s terminate.final @NonNull Completable
Observable.concatMapCompletableDelayError
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper, boolean tillTheEnd) Maps the upstream items intoCompletableSource
s and subscribes to them one after the other terminates, optionally delaying all errors till both the currentObservable
and all innerCompletableSource
s terminate.final @NonNull Completable
Observable.concatMapCompletableDelayError
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper, boolean tillTheEnd, int bufferSize) Maps the upstream items intoCompletableSource
s and subscribes to them one after the other terminates, optionally delaying all errors till both the currentObservable
and all innerCompletableSource
s terminate.static @NonNull Completable
Completable.defer
(@NonNull Supplier<? extends @NonNull CompletableSource> supplier) Defers the subscription to aCompletable
instance returned by a supplier.final @NonNull Completable
Flowable.flatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps each element of the upstreamFlowable
intoCompletableSource
s, subscribes to them and waits until the upstream and allCompletableSource
s complete.final @NonNull Completable
Flowable.flatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper, boolean delayErrors, int maxConcurrency) Maps each element of the upstreamFlowable
intoCompletableSource
s, subscribes to them and waits until the upstream and allCompletableSource
s complete, optionally delaying all errors.final @NonNull Completable
Maybe.flatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Returns aCompletable
that completes based on applying a specified function to the item emitted by the currentMaybe
, where that function returns aCompletable
.final @NonNull Completable
Observable.flatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps each element of the currentObservable
intoCompletableSource
s, subscribes to them and waits until the upstream and allCompletableSource
s complete.final @NonNull Completable
Observable.flatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper, boolean delayErrors) Maps each element of the currentObservable
intoCompletableSource
s, subscribes to them and waits until the upstream and allCompletableSource
s complete, optionally delaying all errors.final @NonNull Completable
Single.flatMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Returns aCompletable
that completes based on applying a specified function to the item emitted by the currentSingle
, where that function returns aCompletableSource
.static @NonNull Completable
Completable.merge
(@NonNull Iterable<@NonNull ? extends CompletableSource> sources) Returns aCompletable
instance that subscribes to all sources at once and completes only when all sourceCompletableSource
s complete or one of them emits an error.static @NonNull Completable
Completable.merge
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources) Returns aCompletable
instance that subscribes to all sources at once and completes only when all sourceCompletableSource
s complete or one of them emits an error.static @NonNull Completable
Completable.merge
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources, int maxConcurrency) Returns aCompletable
instance that keeps subscriptions to a limited number of sources at once and completes only when all sourceCompletableSource
s complete or one of them emits an error.private static @NonNull Completable
Completable.merge0
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources, int maxConcurrency, boolean delayErrors) Returns aCompletable
instance that keeps subscriptions to a limited number ofCompletableSource
s at once and completes only when all sourceCompletableSource
s terminate in one way or another, combining any exceptions signaled by either the sourcePublisher
or the innerCompletableSource
instances.static @NonNull Completable
Completable.mergeDelayError
(@NonNull Iterable<@NonNull ? extends CompletableSource> sources) Returns aCompletable
that subscribes to allCompletableSource
s in the source sequence and delays any error emitted by any of the innerCompletableSource
s until all of them terminate in a way or another.static @NonNull Completable
Completable.mergeDelayError
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources) Returns aCompletable
that subscribes to allCompletableSource
s in the source sequence and delays any error emitted by either the sourcesPublisher
or any of the innerCompletableSource
s until all of them terminate in a way or another.static @NonNull Completable
Completable.mergeDelayError
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources, int maxConcurrency) Returns aCompletable
that subscribes to a limited number of innerCompletableSource
s at once in the source sequence and delays any error emitted by either the sourcesPublisher
or any of the innerCompletableSource
s until all of them terminate in a way or another.final @NonNull Completable
Completable.onErrorResumeNext
(@NonNull Function<? super Throwable, ? extends CompletableSource> fallbackSupplier) Returns aCompletable
instance that when encounters an error from thisCompletable
, calls the specifiedmapper
Function
that returns aCompletableSource
instance for it and resumes the execution with it.final @NonNull Completable
Flowable.switchMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps the upstream values intoCompletableSource
s, subscribes to the newer one while disposing the subscription to the previousCompletableSource
, thus keeping at most one activeCompletableSource
running.final @NonNull Completable
Observable.switchMapCompletable
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps the items of the currentObservable
intoCompletableSource
s, subscribes to the newer one while disposing the subscription to the previousCompletableSource
, thus keeping at most one activeCompletableSource
running.final @NonNull Completable
Flowable.switchMapCompletableDelayError
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps the upstream values intoCompletableSource
s, subscribes to the newer one while disposing the subscription to the previousCompletableSource
, thus keeping at most one activeCompletableSource
running and delaying any main or inner errors until all of them terminate.final @NonNull Completable
Observable.switchMapCompletableDelayError
(@NonNull Function<? super @NonNull T, ? extends CompletableSource> mapper) Maps the upstream values intoCompletableSource
s, subscribes to the newer one while disposing the subscription to the previousCompletableSource
, thus keeping at most one activeCompletableSource
running and delaying any main or inner errors until all of them terminate.static @NonNull Completable
Completable.switchOnNext
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources) Switches betweenCompletableSource
s emitted by the sourcePublisher
whenever a newCompletableSource
is emitted, disposing the previously runningCompletableSource
, exposing the setup as aCompletable
sequence.static @NonNull Completable
Completable.switchOnNextDelayError
(@NonNull org.reactivestreams.Publisher<@NonNull ? extends CompletableSource> sources) Switches betweenCompletableSource
s emitted by the sourcePublisher
whenever a newCompletableSource
is emitted, disposing the previously runningCompletableSource
, exposing the setup as aCompletable
sequence and delaying all errors from all of them until all terminate.static <@NonNull R>
@NonNull CompletableCompletable.using
(@NonNull Supplier<@NonNull R> resourceSupplier, @NonNull Function<? super @NonNull R, ? extends CompletableSource> sourceSupplier, @NonNull Consumer<? super @NonNull R> resourceCleanup) Returns aCompletable
instance which manages a resource along with a customCompletableSource
instance while the subscription is active.static <@NonNull R>
@NonNull CompletableCompletable.using
(@NonNull Supplier<@NonNull R> resourceSupplier, @NonNull Function<? super @NonNull R, ? extends CompletableSource> sourceSupplier, @NonNull Consumer<? super @NonNull R> resourceCleanup, boolean eager) Returns aCompletable
instance which manages a resource along with a customCompletableSource
instance while the subscription is active and performs eager or lazy resource disposition. -
Uses of CompletableSource in io.reactivex.rxjava3.internal.fuseable
Methods in io.reactivex.rxjava3.internal.fuseable that return CompletableSourceModifier and TypeMethodDescriptionHasUpstreamCompletableSource.source()
Returns the upstream source of this Completable. -
Uses of CompletableSource in io.reactivex.rxjava3.internal.jdk8
Classes in io.reactivex.rxjava3.internal.jdk8 that implement CompletableSourceModifier and TypeClassDescriptionfinal class
Wrap a CompletionStage and signal its outcome. -
Uses of CompletableSource in io.reactivex.rxjava3.internal.operators.completable
Classes in io.reactivex.rxjava3.internal.operators.completable that implement CompletableSourceModifier and TypeClassDescriptionfinal class
final class
final class
Consume the upstream source exactly once and cache its terminal event.final class
final class
final class
final class
final class
final class
final class
Breaks the references between the upstream and downstream when the Completable terminates.final class
final class
Execute an action after an onError, onComplete or a dispose event.final class
final class
final class
final class
final class
final class
final class
final class
final class
final class
final class
Call a Supplier for each incoming CompletableObserver and signal completion or the thrown exception.final class
final class
Hides the identity of the upstream Completable and its Disposable sent through onSubscribe.final class
final class
final class
final class
final class
final class
final class
final class
final class
final class
final class
final class
final class
Terminates the sequence if either the main or the other Completable terminate.final class
final class
Signals anonComplete
event after the specified delay.final class
Fields in io.reactivex.rxjava3.internal.operators.completable declared as CompletableSourceModifier and TypeFieldDescription(package private) final CompletableSource
CompletableAndThenCompletable.next
(package private) final CompletableSource
CompletableAndThenCompletable.SourceObserver.next
(package private) final CompletableSource
CompletableTakeUntilCompletable.other
(package private) final CompletableSource
CompletableTimeout.other
(package private) final CompletableSource
CompletableAndThenCompletable.source
(package private) final CompletableSource
CompletableCache.source
(package private) final CompletableSource
CompletableDelay.source
(package private) final CompletableSource
CompletableDetach.source
(package private) final CompletableSource
CompletableDisposeOn.source
(package private) final CompletableSource
CompletableDoFinally.source
(package private) final CompletableSource
CompletableDoOnEvent.source
(package private) final CompletableSource
CompletableFromUnsafeSource.source
(package private) final CompletableSource
CompletableHide.source
(package private) final CompletableSource
CompletableLift.source
(package private) final CompletableSource
CompletableObserveOn.source
(package private) final CompletableSource
CompletableOnErrorComplete.source
(package private) final CompletableSource
CompletableOnErrorReturn.source
(package private) final CompletableSource
CompletablePeek.source
(package private) final CompletableSource
CompletableResumeNext.source
(package private) final CompletableSource
CompletableSubscribeOn.source
(package private) final CompletableSource
CompletableSubscribeOn.SubscribeOnObserver.source
(package private) final CompletableSource
CompletableTimeout.source
(package private) final CompletableSource
CompletableToFlowable.source
(package private) final CompletableSource
CompletableToObservable.source
(package private) final CompletableSource
CompletableToSingle.source
private final CompletableSource[]
CompletableAmb.sources
(package private) final CompletableSource[]
CompletableConcatArray.ConcatInnerObserver.sources
(package private) final CompletableSource[]
CompletableConcatArray.sources
(package private) final CompletableSource[]
CompletableMergeArray.sources
(package private) final CompletableSource[]
CompletableMergeArrayDelayError.sources
Fields in io.reactivex.rxjava3.internal.operators.completable with type parameters of type CompletableSourceModifier and TypeFieldDescription(package private) final Function
<? super R, ? extends CompletableSource> CompletableUsing.completableFunction
(package private) final Supplier
<? extends CompletableSource> CompletableDefer.completableSupplier
(package private) final Function
<? super Throwable, ? extends CompletableSource> CompletableResumeNext.errorMapper
(package private) final Function
<? super Throwable, ? extends CompletableSource> CompletableResumeNext.ResumeNextObserver.errorMapper
(package private) SimpleQueue
<CompletableSource> CompletableConcat.CompletableConcatSubscriber.queue
(package private) final org.reactivestreams.Publisher
<? extends CompletableSource> CompletableMerge.source
(package private) final org.reactivestreams.Publisher
<? extends CompletableSource> CompletableConcat.sources
(package private) final Iterator
<? extends CompletableSource> CompletableConcatIterable.ConcatInnerObserver.sources
(package private) final Iterable
<? extends CompletableSource> CompletableConcatIterable.sources
(package private) final Iterable
<? extends CompletableSource> CompletableMergeDelayErrorIterable.sources
(package private) final Iterable
<? extends CompletableSource> CompletableMergeIterable.sources
private final Iterable
<? extends CompletableSource> CompletableAmb.sourcesIterable
Methods in io.reactivex.rxjava3.internal.operators.completable with parameters of type CompletableSourceModifier and TypeMethodDescriptionvoid
CompletableConcat.CompletableConcatSubscriber.onNext
(CompletableSource t) void
CompletableMerge.CompletableMergeSubscriber.onNext
(CompletableSource t) Constructors in io.reactivex.rxjava3.internal.operators.completable with parameters of type CompletableSourceModifierConstructorDescriptionCompletableAmb
(CompletableSource[] sources, Iterable<? extends CompletableSource> sourcesIterable) CompletableAndThenCompletable
(CompletableSource source, CompletableSource next) CompletableCache
(CompletableSource source) CompletableConcatArray
(CompletableSource[] sources) CompletableDelay
(CompletableSource source, long delay, TimeUnit unit, Scheduler scheduler, boolean delayError) CompletableDetach
(CompletableSource source) CompletableDisposeOn
(CompletableSource source, Scheduler scheduler) CompletableDoFinally
(CompletableSource source, Action onFinally) CompletableDoOnEvent
(CompletableSource source, Consumer<? super Throwable> onEvent) CompletableHide
(CompletableSource source) CompletableLift
(CompletableSource source, CompletableOperator onLift) CompletableMergeArray
(CompletableSource[] sources) CompletableMergeArrayDelayError
(CompletableSource[] sources) CompletableObserveOn
(CompletableSource source, Scheduler scheduler) CompletableOnErrorComplete
(CompletableSource source, Predicate<? super Throwable> predicate) CompletableOnErrorReturn
(CompletableSource source, Function<? super Throwable, ? extends T> valueSupplier) CompletablePeek
(CompletableSource source, Consumer<? super Disposable> onSubscribe, Consumer<? super Throwable> onError, Action onComplete, Action onTerminate, Action onAfterTerminate, Action onDispose) CompletableResumeNext
(CompletableSource source, Function<? super Throwable, ? extends CompletableSource> errorMapper) CompletableSubscribeOn
(CompletableSource source, Scheduler scheduler) CompletableTakeUntilCompletable
(Completable source, CompletableSource other) CompletableTimeout
(CompletableSource source, long timeout, TimeUnit unit, Scheduler scheduler, CompletableSource other) CompletableToSingle
(CompletableSource source, Supplier<? extends T> completionValueSupplier, T completionValue) (package private)
ConcatInnerObserver
(CompletableObserver actual, CompletableSource[] sources) (package private)
SourceObserver
(CompletableObserver actualObserver, CompletableSource next) (package private)
SubscribeOnObserver
(CompletableObserver actual, CompletableSource source) Constructor parameters in io.reactivex.rxjava3.internal.operators.completable with type arguments of type CompletableSourceModifierConstructorDescriptionCompletableAmb
(CompletableSource[] sources, Iterable<? extends CompletableSource> sourcesIterable) CompletableConcat
(org.reactivestreams.Publisher<? extends CompletableSource> sources, int prefetch) CompletableConcatIterable
(Iterable<? extends CompletableSource> sources) CompletableDefer
(Supplier<? extends CompletableSource> completableSupplier) CompletableMerge
(org.reactivestreams.Publisher<? extends CompletableSource> source, int maxConcurrency, boolean delayErrors) CompletableMergeDelayErrorIterable
(Iterable<? extends CompletableSource> sources) CompletableMergeIterable
(Iterable<? extends CompletableSource> sources) CompletableResumeNext
(CompletableSource source, Function<? super Throwable, ? extends CompletableSource> errorMapper) CompletableUsing
(Supplier<R> resourceSupplier, Function<? super R, ? extends CompletableSource> completableFunction, Consumer<? super R> disposer, boolean eager) (package private)
ConcatInnerObserver
(CompletableObserver actual, Iterator<? extends CompletableSource> sources) (package private)
ResumeNextObserver
(CompletableObserver observer, Function<? super Throwable, ? extends CompletableSource> errorMapper) -
Uses of CompletableSource in io.reactivex.rxjava3.internal.operators.flowable
Classes in io.reactivex.rxjava3.internal.operators.flowable that implement CompletableSourceModifier and TypeClassDescriptionfinal class
Maps a sequence of values into CompletableSources and awaits their termination.final class
Fields in io.reactivex.rxjava3.internal.operators.flowable declared as CompletableSourceModifier and TypeFieldDescription(package private) CompletableSource
FlowableConcatWithCompletable.ConcatWithSubscriber.other
(package private) final CompletableSource
FlowableConcatWithCompletable.other
(package private) final CompletableSource
FlowableMergeWithCompletable.other
(package private) final CompletableSource
FlowableFromCompletable.source
Fields in io.reactivex.rxjava3.internal.operators.flowable with type parameters of type CompletableSourceModifier and TypeFieldDescription(package private) final Function
<? super T, ? extends CompletableSource> FlowableFlatMapCompletable.FlatMapCompletableMainSubscriber.mapper
(package private) final Function
<? super T, ? extends CompletableSource> FlowableFlatMapCompletable.mapper
(package private) final Function
<? super T, ? extends CompletableSource> FlowableFlatMapCompletableCompletable.FlatMapCompletableMainSubscriber.mapper
(package private) final Function
<? super T, ? extends CompletableSource> FlowableFlatMapCompletableCompletable.mapper
Methods in io.reactivex.rxjava3.internal.operators.flowable that return CompletableSourceConstructors in io.reactivex.rxjava3.internal.operators.flowable with parameters of type CompletableSourceModifierConstructorDescription(package private)
ConcatWithSubscriber
(org.reactivestreams.Subscriber<? super T> actual, CompletableSource other) FlowableConcatWithCompletable
(Flowable<T> source, CompletableSource other) FlowableMergeWithCompletable
(Flowable<T> source, CompletableSource other) Constructor parameters in io.reactivex.rxjava3.internal.operators.flowable with type arguments of type CompletableSourceModifierConstructorDescription(package private)
FlatMapCompletableMainSubscriber
(org.reactivestreams.Subscriber<? super T> subscriber, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors, int maxConcurrency) (package private)
FlatMapCompletableMainSubscriber
(CompletableObserver observer, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors, int maxConcurrency) FlowableFlatMapCompletable
(Flowable<T> source, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors, int maxConcurrency) FlowableFlatMapCompletableCompletable
(Flowable<T> source, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors, int maxConcurrency) -
Uses of CompletableSource in io.reactivex.rxjava3.internal.operators.maybe
Classes in io.reactivex.rxjava3.internal.operators.maybe that implement CompletableSourceModifier and TypeClassDescriptionfinal class
Maps the success value of the source MaybeSource into a Completable.final class
Turns an onSuccess into an onComplete, onError and onComplete is relayed as is.Fields in io.reactivex.rxjava3.internal.operators.maybe declared as CompletableSourceModifier and TypeFieldDescription(package private) final CompletableSource
MaybeDelayWithCompletable.other
(package private) final CompletableSource
MaybeFromCompletable.source
Fields in io.reactivex.rxjava3.internal.operators.maybe with type parameters of type CompletableSourceModifier and TypeFieldDescription(package private) final Function
<? super T, ? extends CompletableSource> MaybeFlatMapCompletable.FlatMapCompletableObserver.mapper
(package private) final Function
<? super T, ? extends CompletableSource> MaybeFlatMapCompletable.mapper
Methods in io.reactivex.rxjava3.internal.operators.maybe that return CompletableSourceConstructors in io.reactivex.rxjava3.internal.operators.maybe with parameters of type CompletableSourceModifierConstructorDescriptionMaybeDelayWithCompletable
(MaybeSource<T> source, CompletableSource other) Constructor parameters in io.reactivex.rxjava3.internal.operators.maybe with type arguments of type CompletableSourceModifierConstructorDescription(package private)
FlatMapCompletableObserver
(CompletableObserver actual, Function<? super T, ? extends CompletableSource> mapper) MaybeFlatMapCompletable
(MaybeSource<T> source, Function<? super T, ? extends CompletableSource> mapper) -
Uses of CompletableSource in io.reactivex.rxjava3.internal.operators.mixed
Classes in io.reactivex.rxjava3.internal.operators.mixed that implement CompletableSourceModifier and TypeClassDescriptionfinal class
Maps the upstream items intoCompletableSource
s and subscribes to them one after the other completes or terminates (in error-delaying mode).final class
Maps the upstream values intoCompletableSource
s, subscribes to the newer one while disposing the subscription to the previousCompletableSource
, thus keeping at most one activeCompletableSource
running.final class
Switch between subsequentCompletableSource
s emitted by aPublisher
.final class
Maps the upstream items intoCompletableSource
s and subscribes to them one after the other completes or terminates (in error-delaying mode).final class
Maps the upstream values intoCompletableSource
s, subscribes to the newer one while disposing the subscription to the previousCompletableSource
, thus keeping at most one activeCompletableSource
running.Fields in io.reactivex.rxjava3.internal.operators.mixed declared as CompletableSourceModifier and TypeFieldDescription(package private) final CompletableSource
CompletableAndThenObservable.source
(package private) final CompletableSource
CompletableAndThenPublisher.source
Fields in io.reactivex.rxjava3.internal.operators.mixed with type parameters of type CompletableSourceModifier and TypeFieldDescription(package private) final Function
<? super T, ? extends CompletableSource> FlowableConcatMapCompletable.ConcatMapCompletableObserver.mapper
(package private) final Function
<? super T, ? extends CompletableSource> FlowableConcatMapCompletable.mapper
(package private) final Function
<? super T, ? extends CompletableSource> FlowableSwitchMapCompletable.mapper
(package private) final Function
<? super T, ? extends CompletableSource> FlowableSwitchMapCompletable.SwitchMapCompletableObserver.mapper
(package private) final Function
<? super T, ? extends CompletableSource> FlowableSwitchMapCompletablePublisher.mapper
(package private) final Function
<? super T, ? extends CompletableSource> ObservableConcatMapCompletable.ConcatMapCompletableObserver.mapper
(package private) final Function
<? super T, ? extends CompletableSource> ObservableConcatMapCompletable.mapper
(package private) final Function
<? super T, ? extends CompletableSource> ObservableSwitchMapCompletable.mapper
(package private) final Function
<? super T, ? extends CompletableSource> ObservableSwitchMapCompletable.SwitchMapCompletableObserver.mapper
Method parameters in io.reactivex.rxjava3.internal.operators.mixed with type arguments of type CompletableSourceModifier and TypeMethodDescription(package private) static <T> boolean
ScalarXMapZHelper.tryAsCompletable
(Object source, Function<? super T, ? extends CompletableSource> mapper, CompletableObserver observer) Try subscribing to aCompletableSource
mapped from a scalar source (which implementsSupplier
).Constructors in io.reactivex.rxjava3.internal.operators.mixed with parameters of type CompletableSourceModifierConstructorDescriptionCompletableAndThenObservable
(CompletableSource source, ObservableSource<? extends R> other) CompletableAndThenPublisher
(CompletableSource source, org.reactivestreams.Publisher<? extends R> other) Constructor parameters in io.reactivex.rxjava3.internal.operators.mixed with type arguments of type CompletableSourceModifierConstructorDescription(package private)
ConcatMapCompletableObserver
(CompletableObserver downstream, Function<? super T, ? extends CompletableSource> mapper, ErrorMode errorMode, int prefetch) (package private)
ConcatMapCompletableObserver
(CompletableObserver downstream, Function<? super T, ? extends CompletableSource> mapper, ErrorMode errorMode, int prefetch) FlowableConcatMapCompletable
(Flowable<T> source, Function<? super T, ? extends CompletableSource> mapper, ErrorMode errorMode, int prefetch) FlowableSwitchMapCompletable
(Flowable<T> source, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) FlowableSwitchMapCompletablePublisher
(org.reactivestreams.Publisher<T> source, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) ObservableConcatMapCompletable
(Observable<T> source, Function<? super T, ? extends CompletableSource> mapper, ErrorMode errorMode, int prefetch) ObservableSwitchMapCompletable
(Observable<T> source, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) (package private)
SwitchMapCompletableObserver
(CompletableObserver downstream, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) (package private)
SwitchMapCompletableObserver
(CompletableObserver downstream, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) -
Uses of CompletableSource in io.reactivex.rxjava3.internal.operators.observable
Classes in io.reactivex.rxjava3.internal.operators.observable that implement CompletableSourceModifier and TypeClassDescriptionfinal class
Maps a sequence of values into CompletableSources and awaits their termination.final class
Fields in io.reactivex.rxjava3.internal.operators.observable declared as CompletableSourceModifier and TypeFieldDescription(package private) CompletableSource
ObservableConcatWithCompletable.ConcatWithObserver.other
(package private) final CompletableSource
ObservableConcatWithCompletable.other
(package private) final CompletableSource
ObservableMergeWithCompletable.other
(package private) final CompletableSource
ObservableFromCompletable.source
Fields in io.reactivex.rxjava3.internal.operators.observable with type parameters of type CompletableSourceModifier and TypeFieldDescription(package private) final Function
<? super T, ? extends CompletableSource> ObservableFlatMapCompletable.FlatMapCompletableMainObserver.mapper
(package private) final Function
<? super T, ? extends CompletableSource> ObservableFlatMapCompletable.mapper
(package private) final Function
<? super T, ? extends CompletableSource> ObservableFlatMapCompletableCompletable.FlatMapCompletableMainObserver.mapper
(package private) final Function
<? super T, ? extends CompletableSource> ObservableFlatMapCompletableCompletable.mapper
Methods in io.reactivex.rxjava3.internal.operators.observable that return CompletableSourceConstructors in io.reactivex.rxjava3.internal.operators.observable with parameters of type CompletableSourceModifierConstructorDescription(package private)
ConcatWithObserver
(Observer<? super T> actual, CompletableSource other) ObservableConcatWithCompletable
(Observable<T> source, CompletableSource other) ObservableMergeWithCompletable
(Observable<T> source, CompletableSource other) Constructor parameters in io.reactivex.rxjava3.internal.operators.observable with type arguments of type CompletableSourceModifierConstructorDescription(package private)
FlatMapCompletableMainObserver
(Observer<? super T> observer, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) (package private)
FlatMapCompletableMainObserver
(CompletableObserver observer, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) ObservableFlatMapCompletable
(ObservableSource<T> source, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) ObservableFlatMapCompletableCompletable
(ObservableSource<T> source, Function<? super T, ? extends CompletableSource> mapper, boolean delayErrors) -
Uses of CompletableSource in io.reactivex.rxjava3.internal.operators.single
Classes in io.reactivex.rxjava3.internal.operators.single that implement CompletableSourceModifier and TypeClassDescriptionfinal class
Maps the success value of the source SingleSource into a Completable.Fields in io.reactivex.rxjava3.internal.operators.single declared as CompletableSourceModifier and TypeFieldDescription(package private) final CompletableSource
SingleDelayWithCompletable.other
Fields in io.reactivex.rxjava3.internal.operators.single with type parameters of type CompletableSourceModifier and TypeFieldDescription(package private) final Function
<? super T, ? extends CompletableSource> SingleFlatMapCompletable.FlatMapCompletableObserver.mapper
(package private) final Function
<? super T, ? extends CompletableSource> SingleFlatMapCompletable.mapper
Constructors in io.reactivex.rxjava3.internal.operators.single with parameters of type CompletableSourceModifierConstructorDescriptionSingleDelayWithCompletable
(SingleSource<T> source, CompletableSource other) Constructor parameters in io.reactivex.rxjava3.internal.operators.single with type arguments of type CompletableSourceModifierConstructorDescription(package private)
FlatMapCompletableObserver
(CompletableObserver actual, Function<? super T, ? extends CompletableSource> mapper) SingleFlatMapCompletable
(SingleSource<T> source, Function<? super T, ? extends CompletableSource> mapper) -
Uses of CompletableSource in io.reactivex.rxjava3.internal.schedulers
Classes in io.reactivex.rxjava3.internal.schedulers that implement CompletableSourceModifier and TypeClassDescription(package private) final class
-
Uses of CompletableSource in io.reactivex.rxjava3.subjects
Classes in io.reactivex.rxjava3.subjects that implement CompletableSourceModifier and TypeClassDescriptionfinal class
Represents a hot Completable-like source and consumer of events similar to Subjects.