Package | Description |
---|---|
io.reactivex |
Base reactive classes:
Flowable , Observable ,
Single , Maybe and
Completable ; base reactive consumers;
other common base interfaces. |
io.reactivex.internal.fuseable |
Base interfaces and types for supporting operator-fusion.
|
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.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 | Class and Description |
---|---|
class |
Completable
The
Completable class represents a deferred computation without any value but
only indication for completion or exception. |
Modifier and Type | Method and Description |
---|---|
CompletableSource |
CompletableTransformer.apply(Completable upstream)
Applies a function to the upstream Completable and returns a CompletableSource.
|
Modifier and Type | Method and Description |
---|---|
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.
|
static Completable |
Completable.concatArray(CompletableSource... sources)
Returns a Completable which completes only when all sources complete, one after another.
|
Observable<T> |
Observable.concatWith(CompletableSource other)
Returns an
Observable that emits items from this Observable and when it completes normally, the
other CompletableSource is subscribed to and the returned Observable emits its terminal events. |
Flowable<T> |
Flowable.concatWith(CompletableSource other)
Returns a
Flowable that emits items from this Flowable and when it completes normally, the
other CompletableSource is subscribed to and the returned Flowable emits its terminal events. |
Completable |
Completable.concatWith(CompletableSource other)
Concatenates this Completable with another Completable.
|
Single<T> |
Single.delaySubscription(CompletableSource other)
Delays the actual subscription to the current Single until the given other CompletableSource
completes.
|
static <T> Maybe<T> |
Maybe.fromCompletable(CompletableSource completableSource)
Wraps a CompletableSource into a Maybe.
|
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.
|
Observable<T> |
Observable.mergeWith(CompletableSource other)
Relays the items of this Observable and completes only when the other CompletableSource completes
as well.
|
Flowable<T> |
Flowable.mergeWith(CompletableSource other)
Relays the items of this Flowable and completes only when the other CompletableSource completes
as well.
|
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.
|
Completable |
Completable.startWith(CompletableSource other)
Returns a Completable which first runs the other Completable
then this completable if the other completed normally.
|
Single<T> |
Single.takeUntil(CompletableSource other)
Returns a Single that emits the item emitted by the source Single until a Completable terminates.
|
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,
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,
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.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.
|
static Completable |
Completable.wrap(CompletableSource source)
Wraps the given CompletableSource into a Completable
if not already Completable.
|
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.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.
|
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. |
static Completable |
Completable.defer(Callable<? extends CompletableSource> completableSupplier)
Defers the subscription to a Completable instance returned by a supplier.
|
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.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.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.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 |
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. |
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.
|
Modifier and Type | Method and Description |
---|---|
CompletableSource |
HasUpstreamCompletableSource.source()
Returns the upstream source of this Completable.
|
Constructor and Description |
---|
CompletableAmb(CompletableSource[] sources,
Iterable<? extends CompletableSource> sourcesIterable) |
CompletableConcat(org.reactivestreams.Publisher<? extends CompletableSource> sources,
int prefetch) |
CompletableConcatIterable(Iterable<? extends CompletableSource> sources) |
CompletableDefer(Callable<? 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(Callable<R> resourceSupplier,
Function<? super R,? extends CompletableSource> completableFunction,
Consumer<? super R> disposer,
boolean eager) |
Modifier and Type | Class and Description |
---|---|
class |
FlowableFlatMapCompletableCompletable<T>
Maps a sequence of values into CompletableSources and awaits their termination.
|
class |
FlowableIgnoreElementsCompletable<T> |
Constructor and Description |
---|
FlowableConcatWithCompletable(Flowable<T> source,
CompletableSource other) |
FlowableMergeWithCompletable(Flowable<T> source,
CompletableSource other) |
Constructor and Description |
---|
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) |
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 | Method and Description |
---|---|
CompletableSource |
MaybeFromCompletable.source() |
Constructor and Description |
---|
MaybeDelayWithCompletable(MaybeSource<T> source,
CompletableSource other) |
MaybeFromCompletable(CompletableSource source) |
Constructor and Description |
---|
MaybeFlatMapCompletable(MaybeSource<T> source,
Function<? super T,? extends CompletableSource> mapper) |
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. |
Constructor and Description |
---|
CompletableAndThenObservable(CompletableSource source,
ObservableSource<? extends R> other) |
CompletableAndThenPublisher(CompletableSource source,
org.reactivestreams.Publisher<? extends R> other) |
Constructor and Description |
---|
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) |
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) |
Modifier and Type | Class and Description |
---|---|
class |
ObservableFlatMapCompletableCompletable<T>
Maps a sequence of values into CompletableSources and awaits their termination.
|
class |
ObservableIgnoreElementsCompletable<T> |
Constructor and Description |
---|
ObservableConcatWithCompletable(Observable<T> source,
CompletableSource other) |
ObservableMergeWithCompletable(Observable<T> source,
CompletableSource other) |
Constructor and Description |
---|
ObservableFlatMapCompletable(ObservableSource<T> source,
Function<? super T,? extends CompletableSource> mapper,
boolean delayErrors) |
ObservableFlatMapCompletableCompletable(ObservableSource<T> source,
Function<? super T,? extends CompletableSource> mapper,
boolean delayErrors) |
Modifier and Type | Class and Description |
---|---|
class |
SingleFlatMapCompletable<T>
Maps the success value of the source SingleSource into a Completable.
|
Constructor and Description |
---|
SingleDelayWithCompletable(SingleSource<T> source,
CompletableSource other) |
Constructor and Description |
---|
SingleFlatMapCompletable(SingleSource<T> source,
Function<? super T,? extends CompletableSource> mapper) |
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.