Package | Description |
---|---|
io.reactivex |
Base reactive classes:
Flowable , Observable ,
Single , Maybe and
Completable ; base reactive consumers;
other common base interfaces. |
io.reactivex.internal.operators.completable | |
io.reactivex.internal.operators.flowable | |
io.reactivex.internal.operators.maybe | |
io.reactivex.internal.operators.mixed | |
io.reactivex.internal.operators.observable | |
io.reactivex.internal.operators.single | |
io.reactivex.internal.schedulers | |
io.reactivex.plugins |
Contains the central plugin handler
RxJavaPlugins
class to hook into the lifecycle of the base reactive types and schedulers. |
io.reactivex.subjects |
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.
|
Modifier and Type | Method and Description |
---|---|
static Completable |
Completable.amb(Iterable<? extends CompletableSource> sources)
Returns a Completable which terminates as soon as one of the source Completables
terminates (normally or with an error) and disposes all other Completables.
|
static Completable |
Completable.ambArray(CompletableSource... sources)
Returns a Completable which terminates as soon as one of the source Completables
terminates (normally or with an error) and disposes all other Completables.
|
Completable |
Completable.ambWith(CompletableSource other)
Returns a Completable that emits the a terminated event of either this Completable
or the other Completable whichever fires first.
|
Completable |
Completable.andThen(CompletableSource next)
Returns a Completable that first runs this Completable
and then the other completable.
|
Completable |
Completable.cache()
Subscribes to this Completable only once, when the first CompletableObserver
subscribes to the result Completable, caches its terminal event
and relays/replays it to observers.
|
static Completable |
Completable.complete()
Returns a Completable instance that completes immediately when subscribed to.
|
Completable |
Completable.compose(CompletableTransformer transformer)
Calls the given transformer function with this instance and returns the function's resulting
Completable.
|
static Completable |
Completable.concat(Iterable<? extends CompletableSource> sources)
Returns a Completable which completes only when all sources complete, one after another.
|
static Completable |
Completable.concat(org.reactivestreams.Publisher<? extends CompletableSource> sources)
Returns a Completable which completes only when all sources complete, one after another.
|
static Completable |
Completable.concat(org.reactivestreams.Publisher<? extends CompletableSource> sources,
int prefetch)
Returns a Completable which completes only when all sources complete, one after another.
|
static Completable |
Completable.concatArray(CompletableSource... sources)
Returns a Completable which completes only when all sources complete, one after another.
|
Completable |
Observable.concatMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps each element of the upstream Observable into CompletableSources, subscribes to them one at a time in
order and waits until the upstream and all CompletableSources complete.
|
Completable |
Flowable.concatMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other completes. |
Completable |
Observable.concatMapCompletable(Function<? super T,? extends CompletableSource> mapper,
int capacityHint)
Maps each element of the upstream Observable into CompletableSources, subscribes to them one at a time in
order and waits until the upstream and all CompletableSources complete.
|
Completable |
Flowable.concatMapCompletable(Function<? super T,? extends CompletableSource> mapper,
int prefetch)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other completes. |
Completable |
Observable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, delaying all errors till both this Observable and all
inner CompletableSource s terminate. |
Completable |
Flowable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, delaying all errors till both this Flowable and all
inner CompletableSource s terminate. |
Completable |
Observable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper,
boolean tillTheEnd)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, optionally delaying all errors till both this Observable and all
inner CompletableSource s terminate. |
Completable |
Flowable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper,
boolean tillTheEnd)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, optionally delaying all errors till both this Flowable and all
inner CompletableSource s terminate. |
Completable |
Observable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper,
boolean tillTheEnd,
int prefetch)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, optionally delaying all errors till both this Observable and all
inner CompletableSource s terminate. |
Completable |
Flowable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper,
boolean tillTheEnd,
int prefetch)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, optionally delaying all errors till both this Flowable and all
inner CompletableSource s terminate. |
Completable |
Completable.concatWith(CompletableSource other)
Concatenates this Completable with another Completable.
|
static Completable |
Completable.create(CompletableOnSubscribe source)
Provides an API (via a cold Completable) that bridges the reactive world with the callback-style world.
|
static Completable |
Completable.defer(Callable<? extends CompletableSource> completableSupplier)
Defers the subscription to a Completable instance returned by a supplier.
|
Completable |
Completable.delay(long delay,
TimeUnit unit)
Returns a Completable which delays the emission of the completion event by the given time.
|
Completable |
Completable.delay(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Completable which delays the emission of the completion event by the given time while
running on the specified scheduler.
|
Completable |
Completable.delay(long delay,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
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.
|
Completable |
Completable.delaySubscription(long delay,
TimeUnit unit)
Returns a Completable that delays the subscription to the source CompletableSource by a given amount of time.
|
Completable |
Completable.delaySubscription(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Completable that delays the subscription to the source CompletableSource by a given amount of time,
both waiting and subscribing on a given Scheduler.
|
Completable |
Completable.doAfterTerminate(Action onAfterTerminate)
Returns a Completable instance that calls the given onTerminate callback after this Completable
completes normally or with an exception.
|
Completable |
Completable.doFinally(Action onFinally)
Calls the specified action after this Completable signals onError or onComplete or gets disposed by
the downstream.
|
Completable |
Completable.doOnComplete(Action onComplete)
Returns a Completable which calls the given onComplete callback if this Completable completes.
|
Completable |
Completable.doOnDispose(Action onDispose)
Calls the shared
Action if a CompletableObserver subscribed to the current
Completable disposes the common Disposable it received via onSubscribe. |
Completable |
Completable.doOnError(Consumer<? super Throwable> onError)
Returns a Completable which calls the given onError callback if this Completable emits an error.
|
Completable |
Completable.doOnEvent(Consumer<? super Throwable> onEvent)
Returns a Completable which calls the given onEvent callback with the (throwable) for an onError
or (null) for an onComplete signal from this Completable before delivering said signal to the downstream.
|
Completable |
Completable.doOnSubscribe(Consumer<? super Disposable> onSubscribe)
Returns a Completable instance that calls the given onSubscribe callback with the disposable
that child subscribers receive on subscription.
|
Completable |
Completable.doOnTerminate(Action onTerminate)
Returns a Completable instance that calls the given onTerminate callback just before this Completable
completes normally or with an exception.
|
static Completable |
Completable.error(Callable<? extends Throwable> errorSupplier)
Creates a Completable which calls the given error supplier for each subscriber
and emits its returned Throwable.
|
static Completable |
Completable.error(Throwable error)
Creates a Completable instance that emits the given Throwable exception to subscribers.
|
Completable |
Single.flatMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Returns a
Completable that completes based on applying a specified function to the item emitted by the
source Single , where that function returns a Completable . |
Completable |
Observable.flatMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps each element of the upstream Observable into CompletableSources, subscribes to them and
waits until the upstream and all CompletableSources complete.
|
Completable |
Maybe.flatMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Returns a
Completable that completes based on applying a specified function to the item emitted by the
source Maybe , where that function returns a Completable . |
Completable |
Flowable.flatMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps each element of the upstream Flowable into CompletableSources, subscribes to them and
waits until the upstream and all CompletableSources complete.
|
Completable |
Observable.flatMapCompletable(Function<? super T,? extends CompletableSource> mapper,
boolean delayErrors)
Maps each element of the upstream Observable into CompletableSources, subscribes to them and
waits until the upstream and all CompletableSources complete, optionally delaying all errors.
|
Completable |
Flowable.flatMapCompletable(Function<? super T,? extends CompletableSource> mapper,
boolean delayErrors,
int maxConcurrency)
Maps each element of the upstream Flowable into CompletableSources, subscribes to them and
waits until the upstream and all CompletableSources complete, optionally delaying all errors.
|
static Completable |
Completable.fromAction(Action run)
Returns a Completable instance that runs the given Action 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 onComplete 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 <T> Completable |
Completable.fromMaybe(MaybeSource<T> maybe)
Returns a Completable instance that when subscribed to, subscribes to the
Maybe instance and
emits a completion event if the maybe emits onSuccess /onComplete or forwards any
onError events. |
static <T> Completable |
Completable.fromObservable(ObservableSource<T> observable)
Returns a Completable instance that subscribes to the given Observable, ignores all values and
emits only the terminal event.
|
static <T> Completable |
Completable.fromPublisher(org.reactivestreams.Publisher<T> publisher)
Returns a Completable instance that subscribes to the given publisher, ignores all values and
emits only the terminal event.
|
static Completable |
Completable.fromRunnable(Runnable run)
Returns a Completable instance that runs the given Runnable for each subscriber and
emits either its exception or simply completes.
|
static <T> Completable |
Completable.fromSingle(SingleSource<T> 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.
|
Completable |
Completable.hide()
Hides the identity of this Completable and its Disposable.
|
Completable |
Single.ignoreElement()
Returns a
Completable that ignores the success value of this Single
and calls onComplete instead on the returned Completable . |
Completable |
Maybe.ignoreElement()
Ignores the item emitted by the source Maybe and only calls
onComplete or onError . |
Completable |
Observable.ignoreElements()
Ignores all items emitted by the source ObservableSource and only calls
onComplete or onError . |
Completable |
Flowable.ignoreElements()
Ignores all items emitted by the source Publisher and only calls
onComplete or onError . |
Completable |
Completable.lift(CompletableOperator onLift)
This method requires advanced knowledge about building operators, please consider
other standard composition methods first;
Returns a
Completable which, when subscribed to, invokes the apply(CompletableObserver) method
of the provided CompletableOperator for each individual downstream Completable and allows the
insertion of a custom operator by accessing the downstream's CompletableObserver during this subscription phase
and providing a new CompletableObserver , containing the custom operator's intended business logic, that will be
used in the subscription process going further upstream. |
static Completable |
Completable.merge(Iterable<? extends CompletableSource> 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(org.reactivestreams.Publisher<? extends CompletableSource> 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(org.reactivestreams.Publisher<? extends CompletableSource> 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.
|
static Completable |
Completable.mergeArray(CompletableSource... 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.mergeArrayDelayError(CompletableSource... sources)
Returns a CompletableConsumable 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(Iterable<? extends CompletableSource> 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(org.reactivestreams.Publisher<? extends CompletableSource> 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(org.reactivestreams.Publisher<? extends CompletableSource> 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.
|
Completable |
Completable.mergeWith(CompletableSource 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.
|
Completable |
Completable.observeOn(Scheduler scheduler)
Returns a Completable which emits the terminal events from the thread of the specified scheduler.
|
Completable |
Completable.onErrorComplete()
Returns a Completable instance that if this Completable emits an error, it will emit an onComplete
and swallow the throwable.
|
Completable |
Completable.onErrorComplete(Predicate<? super Throwable> 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.
|
Completable |
Completable.onErrorResumeNext(Function<? super Throwable,? extends CompletableSource> 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.
|
Completable |
Completable.onTerminateDetach()
Nulls out references to the upstream producer and downstream CompletableObserver if
the sequence is terminated or downstream calls dispose().
|
Completable |
Completable.repeat()
Returns a Completable that repeatedly subscribes to this Completable until disposed.
|
Completable |
Completable.repeat(long times)
Returns a Completable that subscribes repeatedly at most the given times to this Completable.
|
Completable |
Completable.repeatUntil(BooleanSupplier stop)
Returns a Completable that repeatedly subscribes to this Completable so long as the given
stop supplier returns false.
|
Completable |
Completable.repeatWhen(Function<? super Flowable<Object>,? extends org.reactivestreams.Publisher<?>> 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.
|
Completable |
Completable.retry()
Returns a Completable that retries this Completable as long as it emits an onError event.
|
Completable |
Completable.retry(BiPredicate<? super Integer,? super Throwable> predicate)
Returns a Completable that retries this Completable in case of an error as long as the predicate
returns true.
|
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.
|
Completable |
Completable.retry(long times,
Predicate<? super Throwable> predicate)
Returns a Completable that when this Completable emits an error, retries at most times
or until the predicate returns false, whichever happens first and emitting the last error.
|
Completable |
Completable.retry(Predicate<? super Throwable> predicate)
Returns a Completable that when this Completable emits an error, calls the given predicate with
the latest exception to decide whether to resubscribe to this or not.
|
Completable |
Completable.retryWhen(Function<? super Flowable<Throwable>,? extends org.reactivestreams.Publisher<?>> handler)
Returns a Completable which given a Publisher and when this Completable emits an error, delivers
that error through a Flowable and the Publisher should signal a value indicating a retry in response
or a terminal event indicating a termination.
|
Completable |
Completable.startWith(CompletableSource other)
Returns a Completable which first runs the other Completable
then this completable if the other completed normally.
|
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.
|
Completable |
Observable.switchMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream values into
CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running. |
Completable |
Flowable.switchMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream values into
CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running. |
Completable |
Observable.switchMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream values into
CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running and delaying any main or inner errors until all
of them terminate. |
Completable |
Flowable.switchMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream values into
CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running and delaying any main or inner errors until all
of them terminate. |
Completable |
Completable.takeUntil(CompletableSource other)
Terminates the downstream if this or the other
Completable
terminates (wins the termination race) while disposing the connection to the losing source. |
Completable |
Completable.timeout(long timeout,
TimeUnit unit)
Returns a Completable that runs this Completable and emits a TimeoutException in case
this Completable doesn't complete within the given time.
|
Completable |
Completable.timeout(long timeout,
TimeUnit unit,
CompletableSource 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.
|
Completable |
Completable.timeout(long timeout,
TimeUnit unit,
Scheduler scheduler)
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.
|
Completable |
Completable.timeout(long timeout,
TimeUnit unit,
Scheduler scheduler,
CompletableSource 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.
|
static Completable |
Completable.timer(long delay,
TimeUnit unit)
Returns a Completable instance that fires its onComplete event after the given delay elapsed.
|
static Completable |
Completable.timer(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Completable instance that fires its onComplete event after the given delay elapsed
by using the supplied scheduler.
|
Completable |
Single.toCompletable()
Deprecated.
see
Single.ignoreElement() instead, will be removed in 3.0 |
static Completable |
Completable.unsafeCreate(CompletableSource source)
Constructs a Completable instance by wrapping the given source callback
without any safeguards; you should manage the lifecycle and response
to downstream disposal.
|
Completable |
Completable.unsubscribeOn(Scheduler scheduler)
Returns a Completable which makes sure when a subscriber disposes the subscription, the
dispose is called on the specified scheduler.
|
static <R> Completable |
Completable.using(Callable<R> resourceSupplier,
Function<? super R,? extends CompletableSource> completableFunction,
Consumer<? 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(Callable<R> resourceSupplier,
Function<? super R,? extends CompletableSource> completableFunction,
Consumer<? 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.
|
static Completable |
Completable.wrap(CompletableSource source)
Wraps the given CompletableSource into a Completable
if not already Completable.
|
Modifier and Type | Method and Description |
---|---|
CompletableSource |
CompletableTransformer.apply(Completable upstream)
Applies a function to the upstream Completable and returns a CompletableSource.
|
R |
CompletableConverter.apply(Completable upstream)
Applies a function to the upstream Completable and returns a converted value of type
R . |
Modifier and Type | Method and Description |
---|---|
<U> U |
Completable.to(Function<? super Completable,U> converter)
Allows fluent conversion to another type via a function callback.
|
<S extends Scheduler & Disposable> |
Scheduler.when(Function<Flowable<Flowable<Completable>>,Completable> combine)
Allows the use of operators for controlling the timing around when
actions scheduled on workers are actually done.
|
<S extends Scheduler & Disposable> |
Scheduler.when(Function<Flowable<Flowable<Completable>>,Completable> combine)
Allows the use of operators for controlling the timing around when
actions scheduled on workers are actually done.
|
Modifier and Type | Field and Description |
---|---|
static Completable |
CompletableNever.INSTANCE |
static Completable |
CompletableEmpty.INSTANCE |
Constructor and Description |
---|
CompletableMaterialize(Completable source) |
CompletableTakeUntilCompletable(Completable source,
CompletableSource other) |
Modifier and Type | Class and Description |
---|---|
class |
FlowableFlatMapCompletableCompletable<T>
Maps a sequence of values into CompletableSources and awaits their termination.
|
class |
FlowableIgnoreElementsCompletable<T> |
Modifier and Type | Class and Description |
---|---|
class |
MaybeFlatMapCompletable<T>
Maps the success value of the source MaybeSource into a Completable.
|
class |
MaybeIgnoreElementCompletable<T>
Turns an onSuccess into an onComplete, onError and onComplete is relayed as is.
|
Modifier and Type | Class and Description |
---|---|
class |
FlowableConcatMapCompletable<T>
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other completes or terminates (in error-delaying mode). |
class |
FlowableSwitchMapCompletable<T>
Maps the upstream values into
CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running. |
class |
ObservableConcatMapCompletable<T>
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other completes or terminates (in error-delaying mode). |
class |
ObservableSwitchMapCompletable<T>
Maps the upstream values into
CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running. |
Modifier and Type | Class and Description |
---|---|
class |
ObservableFlatMapCompletableCompletable<T>
Maps a sequence of values into CompletableSources and awaits their termination.
|
class |
ObservableIgnoreElementsCompletable<T> |
Modifier and Type | Class and Description |
---|---|
class |
SingleFlatMapCompletable<T>
Maps the success value of the source SingleSource into a Completable.
|
Constructor and Description |
---|
SchedulerWhen(Function<Flowable<Flowable<Completable>>,Completable> combine,
Scheduler actualScheduler) |
SchedulerWhen(Function<Flowable<Flowable<Completable>>,Completable> combine,
Scheduler actualScheduler) |
Modifier and Type | Method and Description |
---|---|
static Completable |
RxJavaPlugins.onAssembly(Completable source)
Calls the associated hook function.
|
Modifier and Type | Method and Description |
---|---|
static Function<? super Completable,? extends Completable> |
RxJavaPlugins.getOnCompletableAssembly()
Returns the current hook function.
|
static Function<? super Completable,? extends Completable> |
RxJavaPlugins.getOnCompletableAssembly()
Returns the current hook function.
|
static BiFunction<? super Completable,? super CompletableObserver,? extends CompletableObserver> |
RxJavaPlugins.getOnCompletableSubscribe()
Returns the current hook function.
|
Modifier and Type | Method and Description |
---|---|
static Completable |
RxJavaPlugins.onAssembly(Completable source)
Calls the associated hook function.
|
static CompletableObserver |
RxJavaPlugins.onSubscribe(Completable source,
CompletableObserver observer)
Calls the associated hook function.
|
Modifier and Type | Method and Description |
---|---|
static void |
RxJavaPlugins.setOnCompletableAssembly(Function<? super Completable,? extends Completable> onCompletableAssembly)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setOnCompletableAssembly(Function<? super Completable,? extends Completable> onCompletableAssembly)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setOnCompletableSubscribe(BiFunction<? super Completable,? super CompletableObserver,? extends CompletableObserver> onCompletableSubscribe)
Sets the specific hook function.
|
Modifier and Type | Class and Description |
---|---|
class |
CompletableSubject
Represents a hot Completable-like source and consumer of events similar to Subjects.
|
Copyright © 2019. All rights reserved.