Package | Description |
---|---|
rx |
Base reactive classes: Observable, Single and Completable; base reactive consumers;
other common base interfaces.
|
rx.plugins |
Callback types and a central plugin handler class to hook into the lifecycle
of the base reactive types and schedulers.
|
Modifier and Type | Method and Description |
---|---|
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.
|
static 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.
|
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.
|
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.
|
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(Completable... sources)
Returns a Completable which completes only when all sources complete, one after another.
|
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.
|
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.
|
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.doAfterTerminate(Action0 onAfterComplete)
Returns a Completable instance that calls the given onAfterComplete callback after this
Completable completes normally.
|
Completable |
Completable.doOnComplete(Action0 onComplete)
Deprecated.
Use
doOnCompleted(Action0) instead. |
Completable |
Completable.doOnCompleted(Action0 onCompleted)
Returns a Completable which calls the given onCompleted callback if this Completable completes.
|
Completable |
Completable.doOnError(Action1<? super Throwable> onError)
Returns a Completable which calls the given onError callback if this Completable emits an error.
|
protected 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.
|
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.
|
Completable |
Completable.doOnTerminate(Action0 onTerminate)
Returns a Completable instance that calls the given onTerminate callback just before this Completable
completes normally or with an exception
|
Completable |
Completable.doOnUnsubscribe(Action0 onUnsubscribe)
Returns a Completable which calls the given onUnsubscribe callback if the child subscriber cancels
the subscription.
|
Completable |
Completable.endWith(Completable other)
Deprecated.
Use
andThen(rx.Completable) instead. |
static Completable |
Completable.error(Func0<? extends Throwable> errorFunc0)
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.
|
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.
|
Completable |
Completable.lift(Completable.CompletableOperator onLift)
Lifts a CompletableSubscriber transformation into the chain of Completables.
|
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(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(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(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.
|
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.
|
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(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.
|
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.
|
Completable |
Completable.repeat()
Returns a Completable that repeatedly subscribes to this Completable until cancelled.
|
Completable |
Completable.repeat(long times)
Returns a Completable that subscribes repeatedly at most the given times to this Completable.
|
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.
|
Completable |
Completable.retry()
Returns a Completable that retries this Completable as long as it emits an onError event.
|
Completable |
Completable.retry(Func2<Integer,Throwable,Boolean> 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.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.
|
Completable |
Completable.startWith(Completable 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 |
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,
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.
|
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,
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.
|
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 |
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 onCompleted event after the given delay elapsed
by using the supplied scheduler.
|
Completable |
Observable.toCompletable()
Returns a Completable that discards all onNext emissions (similar to
ignoreAllElements() ) and calls onCompleted when this source observable calls
onCompleted. |
Completable |
Single.toCompletable()
Returns a
Completable that discards result of the Single (similar to
Observable.ignoreElements() ) and calls onCompleted when this source Single calls
onSuccess . |
Completable |
Completable.unsubscribeOn(Scheduler scheduler)
Returns a Completable which makes sure when a subscriber cancels the subscription, the
dispose is called on the specified scheduler
|
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.
|
Modifier and Type | Method and Description |
---|---|
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.
|
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.
|
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.
|
Completable |
Completable.concatWith(Completable other)
Concatenates this Completable with another Completable.
|
Completable |
Completable.endWith(Completable other)
Deprecated.
Use
andThen(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.
|
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.
|
Completable |
Completable.startWith(Completable other)
Returns a Completable which first runs the other Completable
then this completable if the other completed normally.
|
Single<T> |
Single.takeUntil(Completable other)
Returns a Single that emits the item emitted by the source Single until a Completable terminates.
|
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.
|
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.
|
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.
|
Modifier and Type | Method and Description |
---|---|
static 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.
|
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.
|
<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> |
Scheduler.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> |
Scheduler.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.
|
Modifier and Type | Method and Description |
---|---|
static Func2<Completable,Completable.CompletableOnSubscribe,Completable.CompletableOnSubscribe> |
RxJavaHooks.getOnCompletableStart()
Returns the current Completable onStart hook function or null if it is
set to the default pass-through.
|
Modifier and Type | Method and Description |
---|---|
static <T> Completable.CompletableOnSubscribe |
RxJavaHooks.onCompletableStart(Completable instance,
Completable.CompletableOnSubscribe onSubscribe)
Hook to call before the child subscriber is subscribed to the OnSubscribe action.
|
Completable.CompletableOnSubscribe |
RxJavaCompletableExecutionHook.onSubscribeStart(Completable completableInstance,
Completable.CompletableOnSubscribe onSubscribe)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static 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.
|
Copyright © 2019. All rights reserved.