Package | Description |
---|---|
io.reactivex |
Base reactive classes:
Flowable , Observable ,
Single , Maybe and
Completable ; base reactive consumers;
other common base interfaces. |
io.reactivex.disposables |
Default implementations for Disposable-based resource management
(Disposable container types) and utility classes to construct
Disposables from callbacks and other types.
|
io.reactivex.internal.functions | |
io.reactivex.internal.observers | |
io.reactivex.internal.operators.completable | |
io.reactivex.internal.operators.flowable | |
io.reactivex.internal.operators.maybe | |
io.reactivex.internal.operators.observable | |
io.reactivex.internal.operators.parallel | |
io.reactivex.internal.operators.single | |
io.reactivex.internal.subscribers | |
io.reactivex.internal.util | |
io.reactivex.parallel |
Contains the base type
ParallelFlowable ,
a sub-DSL for working with Flowable sequences in parallel. |
Modifier and Type | Method and Description |
---|---|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Observable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
int bufferSize)
Subscribes to the source and calls the given callbacks on the current thread.
|
Completable |
Completable.doAfterTerminate(Action onAfterTerminate)
Returns a Completable instance that calls the given onTerminate callback after this Completable
completes normally or with an exception.
|
Maybe<T> |
Maybe.doAfterTerminate(Action onAfterTerminate)
|
Flowable<T> |
Flowable.doAfterTerminate(Action onAfterTerminate)
|
Single<T> |
Single.doAfterTerminate(Action onAfterTerminate)
Registers an
Action to be called after this Single invokes either onSuccess or onError. |
Observable<T> |
Observable.doAfterTerminate(Action onFinally)
|
Completable |
Completable.doFinally(Action onFinally)
Calls the specified action after this Completable signals onError or onComplete or gets disposed by
the downstream.
|
Maybe<T> |
Maybe.doFinally(Action onFinally)
Calls the specified action after this Maybe signals onSuccess, onError or onComplete or gets disposed by
the downstream.
|
Flowable<T> |
Flowable.doFinally(Action onFinally)
Calls the specified action after this Flowable signals onError or onCompleted or gets canceled by
the downstream.
|
Single<T> |
Single.doFinally(Action onFinally)
Calls the specified action after this Single signals onSuccess or onError or gets disposed by
the downstream.
|
Observable<T> |
Observable.doFinally(Action onFinally)
Calls the specified action after this Observable signals onError or onCompleted or gets disposed by
the downstream.
|
Flowable<T> |
Flowable.doOnCancel(Action onCancel)
Calls the cancel
Action if the downstream cancels the sequence. |
Completable |
Completable.doOnComplete(Action onComplete)
Returns a Completable which calls the given onComplete callback if this Completable completes.
|
Maybe<T> |
Maybe.doOnComplete(Action onComplete)
Modifies the source Maybe so that it invokes an action when it calls
onComplete . |
Flowable<T> |
Flowable.doOnComplete(Action onComplete)
Modifies the source Publisher so that it invokes an action when it calls
onComplete . |
Observable<T> |
Observable.doOnComplete(Action onComplete)
Modifies the source ObservableSource so that it invokes an action when it calls
onComplete . |
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. |
Maybe<T> |
Maybe.doOnDispose(Action onDispose)
Calls the shared
Action if a MaybeObserver subscribed to the current Maybe
disposes the common Disposable it received via onSubscribe. |
Single<T> |
Single.doOnDispose(Action onDispose)
Calls the shared
Action if a SingleObserver subscribed to the current Single
disposes the common Disposable it received via onSubscribe. |
Observable<T> |
Observable.doOnDispose(Action onDispose)
Calls the dispose
Action if the downstream disposes the sequence. |
Observable<T> |
Observable.doOnLifecycle(Consumer<? super Disposable> onSubscribe,
Action onDispose)
Calls the appropriate onXXX method (shared between all Observer) for the lifecycle events of
the sequence (subscription, cancellation, requesting).
|
Flowable<T> |
Flowable.doOnLifecycle(Consumer<? super org.reactivestreams.Subscription> onSubscribe,
LongConsumer onRequest,
Action onCancel)
Calls the appropriate onXXX method (shared between all Subscribers) for the lifecycle events of
the sequence (subscription, cancellation, requesting).
|
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.
|
Flowable<T> |
Flowable.doOnTerminate(Action onTerminate)
Modifies the source Publisher so that it invokes an action when it calls
onComplete or
onError . |
Observable<T> |
Observable.doOnTerminate(Action onTerminate)
Modifies the source ObservableSource so that it invokes an action when it calls
onComplete or
onError . |
Disposable |
Flowable.forEachWhile(Predicate<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to the
Publisher and receives notifications for each element and the terminal events until the
onNext Predicate returns false. |
Disposable |
Observable.forEachWhile(Predicate<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to the
ObservableSource and receives notifications for each element and the terminal events until the
onNext Predicate returns false. |
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 <T> Maybe<T> |
Maybe.fromAction(Action run)
Returns a Maybe instance that runs the given Action for each subscriber and
emits either its exception or simply completes.
|
Flowable<T> |
Flowable.onBackpressureBuffer(int capacity,
Action onOverflow)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(int capacity,
boolean delayError,
boolean unbounded,
Action onOverflow)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(long capacity,
Action onOverflow,
BackpressureOverflowStrategy overflowStrategy)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Disposable |
Completable.subscribe(Action onComplete)
Subscribes to this Completable and calls the given Action when this Completable
completes normally.
|
Disposable |
Completable.subscribe(Action onComplete,
Consumer<? super Throwable> onError)
Subscribes to this Completable and calls back either the onError or onComplete functions.
|
Disposable |
Maybe.subscribe(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to a Maybe and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
Disposable |
Flowable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
Disposable |
Observable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to an ObservableSource and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
Disposable |
Observable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super Disposable> onSubscribe)
Subscribes to an ObservableSource and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
Disposable |
Flowable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super org.reactivestreams.Subscription> onSubscribe)
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
Modifier and Type | Method and Description |
---|---|
static Disposable |
Disposables.fromAction(Action run)
Construct a Disposable by wrapping a Action that is
executed exactly once when the Disposable is disposed.
|
Modifier and Type | Field and Description |
---|---|
static Action |
Functions.EMPTY_ACTION |
Modifier and Type | Method and Description |
---|---|
static Action |
Functions.futureAction(Future<?> future)
Wraps the blocking get call of the Future into an Action.
|
static <T> Action |
Functions.notificationOnComplete(Consumer<? super Notification<T>> onNotification) |
Modifier and Type | Method and Description |
---|---|
static <T> Consumer<T> |
Functions.actionConsumer(Action action) |
Constructor and Description |
---|
CallbackCompletableObserver(Action onComplete) |
CallbackCompletableObserver(Consumer<? super Throwable> onError,
Action onComplete) |
DisposableLambdaObserver(Observer<? super T> actual,
Consumer<? super Disposable> onSubscribe,
Action onDispose) |
ForEachWhileObserver(Predicate<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete) |
LambdaObserver(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super Disposable> onSubscribe) |
Constructor and Description |
---|
CompletableDoFinally(CompletableSource source,
Action onFinally) |
CompletableFromAction(Action run) |
CompletablePeek(CompletableSource source,
Consumer<? super Disposable> onSubscribe,
Consumer<? super Throwable> onError,
Action onComplete,
Action onTerminate,
Action onAfterTerminate,
Action onDispose) |
Modifier and Type | Method and Description |
---|---|
static <T> Action |
FlowableInternalHelper.subscriberOnComplete(org.reactivestreams.Subscriber<T> subscriber) |
Modifier and Type | Method and Description |
---|---|
static <T> void |
FlowableBlockingSubscribe.subscribe(org.reactivestreams.Publisher<? extends T> o,
Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to the source and calls the given actions on the current thread.
|
static <T> void |
FlowableBlockingSubscribe.subscribe(org.reactivestreams.Publisher<? extends T> o,
Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
int bufferSize)
Subscribes to the source and calls the given actions on the current thread.
|
Constructor and Description |
---|
FlowableDoFinally(Flowable<T> source,
Action onFinally) |
FlowableDoOnEach(Flowable<T> source,
Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Action onAfterTerminate) |
FlowableDoOnLifecycle(Flowable<T> source,
Consumer<? super org.reactivestreams.Subscription> onSubscribe,
LongConsumer onRequest,
Action onCancel) |
FlowableOnBackpressureBuffer(Flowable<T> source,
int bufferSize,
boolean unbounded,
boolean delayError,
Action onOverflow) |
FlowableOnBackpressureBufferStrategy(Flowable<T> source,
long bufferSize,
Action onOverflow,
BackpressureOverflowStrategy strategy) |
Constructor and Description |
---|
MaybeCallbackObserver(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError,
Action onComplete) |
MaybeDoFinally(MaybeSource<T> source,
Action onFinally) |
MaybeFromAction(Action action) |
MaybePeek(MaybeSource<T> source,
Consumer<? super Disposable> onSubscribeCall,
Consumer<? super T> onSuccessCall,
Consumer<? super Throwable> onErrorCall,
Action onCompleteCall,
Action onAfterTerminate,
Action onDispose) |
Modifier and Type | Method and Description |
---|---|
static <T> Action |
ObservableInternalHelper.observerOnComplete(Observer<T> observer) |
Modifier and Type | Method and Description |
---|---|
static <T> void |
ObservableBlockingSubscribe.subscribe(ObservableSource<? extends T> o,
Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to the source and calls the given actions on the current thread.
|
Constructor and Description |
---|
ObservableDoFinally(ObservableSource<T> source,
Action onFinally) |
ObservableDoOnEach(ObservableSource<T> source,
Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Action onAfterTerminate) |
ObservableDoOnLifecycle(Observable<T> upstream,
Consumer<? super Disposable> onSubscribe,
Action onDispose) |
Constructor and Description |
---|
ParallelPeek(ParallelFlowable<T> source,
Consumer<? super T> onNext,
Consumer<? super T> onAfterNext,
Consumer<? super Throwable> onError,
Action onComplete,
Action onAfterTerminated,
Consumer<? super org.reactivestreams.Subscription> onSubscribe,
LongConsumer onRequest,
Action onCancel) |
Constructor and Description |
---|
SingleDoAfterTerminate(SingleSource<T> source,
Action onAfterTerminate) |
SingleDoFinally(SingleSource<T> source,
Action onFinally) |
SingleDoOnDispose(SingleSource<T> source,
Action onDispose) |
Constructor and Description |
---|
BoundedSubscriber(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super org.reactivestreams.Subscription> onSubscribe,
int bufferSize) |
ForEachWhileSubscriber(Predicate<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete) |
LambdaSubscriber(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super org.reactivestreams.Subscription> onSubscribe) |
Modifier and Type | Class and Description |
---|---|
class |
BlockingIgnoringReceiver
Stores an incoming Throwable (if any) and counts itself down.
|
Modifier and Type | Method and Description |
---|---|
ParallelFlowable<T> |
ParallelFlowable.doAfterTerminated(Action onAfterTerminate)
Run the specified Action when a 'rail' completes or signals an error.
|
ParallelFlowable<T> |
ParallelFlowable.doOnCancel(Action onCancel)
Run the specified Action when a 'rail' receives a cancellation.
|
ParallelFlowable<T> |
ParallelFlowable.doOnComplete(Action onComplete)
Run the specified Action when a 'rail' completes.
|
Copyright © 2018 JBoss by Red Hat. All rights reserved.