Package | Description |
---|---|
io.reactivex |
Base reactive classes:
Flowable , Observable ,
Single , Maybe and
Completable ; base reactive consumers;
other common base interfaces. |
io.reactivex.flowables |
Classes supporting the Flowable base reactive class:
ConnectableFlowable and
GroupedFlowable . |
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.observables |
Classes supporting the Observable base reactive class:
ConnectableObservable and
GroupedObservable . |
io.reactivex.observers |
Default wrappers and implementations for Observer-based consumer classes and interfaces,
including disposable and resource-tracking variants and
the
TestObserver that allows unit testing
Observable -, Single -, Maybe -
and Completable -based flows. |
io.reactivex.parallel |
Contains the base type
ParallelFlowable ,
a sub-DSL for working with Flowable sequences in parallel. |
io.reactivex.plugins |
Contains the central plugin handler
RxJavaPlugins
class to hook into the lifecycle of the base reactive types and schedulers. |
io.reactivex.subscribers |
Default wrappers and implementations for Subscriber-based consumer classes and interfaces,
including disposable and resource-tracking variants and
the
TestSubscriber that allows unit testing
Flowable -based flows. |
Modifier and Type | Method and Description |
---|---|
void |
Flowable.blockingForEach(Consumer<? super T> onNext)
Consumes the upstream
Flowable in a blocking fashion and invokes the given
Consumer with each upstream item on the current thread until the
upstream terminates. |
void |
Observable.blockingForEach(Consumer<? super T> onNext)
Consumes the upstream
Observable in a blocking fashion and invokes the given
Consumer with each upstream item on the current thread until the
upstream terminates. |
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Observable.blockingSubscribe(Consumer<? super T> onNext)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Observable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Observable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
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)
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)
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 |
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.
|
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.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
int bufferSize)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
int bufferSize)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
int bufferSize)
Subscribes to the source and calls the given callbacks on the current thread.
|
Flowable<T> |
Flowable.doAfterNext(Consumer<? super T> onAfterNext)
Calls the specified consumer with the current item after this item has been emitted to the downstream.
|
Observable<T> |
Observable.doAfterNext(Consumer<? super T> onAfterNext)
Calls the specified consumer with the current item after this item has been emitted to the downstream.
|
Maybe<T> |
Maybe.doAfterSuccess(Consumer<? super T> onAfterSuccess)
Calls the specified consumer with the success item after this item has been emitted to the downstream.
|
Single<T> |
Single.doAfterSuccess(Consumer<? super T> onAfterSuccess)
Calls the specified consumer with the success item after this item has been emitted to the downstream.
|
Flowable<T> |
Flowable.doOnEach(Consumer<? super Notification<T>> onNotification)
Modifies the source Publisher so that it invokes an action for each item it emits.
|
Observable<T> |
Observable.doOnEach(Consumer<? super Notification<T>> onNotification)
Modifies the source ObservableSource so that it invokes an action for each item it emits.
|
Completable |
Completable.doOnError(Consumer<? super Throwable> onError)
Returns a Completable which calls the given onError callback if this Completable emits an error.
|
Maybe<T> |
Maybe.doOnError(Consumer<? super Throwable> onError)
Calls the shared consumer with the error sent via onError for each
MaybeObserver that subscribes to the current Maybe.
|
Flowable<T> |
Flowable.doOnError(Consumer<? super Throwable> onError)
Modifies the source Publisher so that it invokes an action if it calls
onError . |
Single<T> |
Single.doOnError(Consumer<? super Throwable> onError)
Calls the shared consumer with the error sent via onError for each
SingleObserver that subscribes to the current Single.
|
Observable<T> |
Observable.doOnError(Consumer<? super Throwable> onError)
Modifies the source ObservableSource so that it invokes an action if it calls
onError . |
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.
|
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).
|
Flowable<T> |
Flowable.doOnNext(Consumer<? super T> onNext)
Modifies the source Publisher so that it invokes an action when it calls
onNext . |
Observable<T> |
Observable.doOnNext(Consumer<? super T> onNext)
Modifies the source ObservableSource so that it invokes an action when it calls
onNext . |
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.
|
Maybe<T> |
Maybe.doOnSubscribe(Consumer<? super Disposable> onSubscribe)
Calls the shared consumer with the Disposable sent through the onSubscribe for each
MaybeObserver that subscribes to the current Maybe.
|
Single<T> |
Single.doOnSubscribe(Consumer<? super Disposable> onSubscribe)
Calls the shared consumer with the Disposable sent through the onSubscribe for each
SingleObserver that subscribes to the current Single.
|
Observable<T> |
Observable.doOnSubscribe(Consumer<? super Disposable> onSubscribe)
Modifies the source
ObservableSource so that it invokes the given action when it is subscribed from
its subscribers. |
Flowable<T> |
Flowable.doOnSubscribe(Consumer<? super org.reactivestreams.Subscription> onSubscribe)
Modifies the source
Publisher so that it invokes the given action when it is subscribed from
its subscribers. |
Maybe<T> |
Maybe.doOnSuccess(Consumer<? super T> onSuccess)
Calls the shared consumer with the success value sent via onSuccess for each
MaybeObserver that subscribes to the current Maybe.
|
Single<T> |
Single.doOnSuccess(Consumer<? super T> onSuccess)
Calls the shared consumer with the success value sent via onSuccess for each
SingleObserver that subscribes to the current Single.
|
Disposable |
Flowable.forEach(Consumer<? super T> onNext)
Subscribes to the
Publisher and receives notifications for each element. |
Disposable |
Observable.forEach(Consumer<? super T> onNext)
Subscribes to the
ObservableSource and receives notifications for each element. |
Disposable |
Flowable.forEachWhile(Predicate<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to the
Publisher and receives notifications for each element and error events until the
onNext Predicate returns false. |
Disposable |
Observable.forEachWhile(Predicate<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to the
ObservableSource and receives notifications for each element and error events until the
onNext Predicate returns false. |
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 <T,S> Flowable<T> |
Flowable.generate(Callable<S> initialState,
BiConsumer<S,Emitter<T>> generator,
Consumer<? super S> disposeState)
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
|
static <T,S> Observable<T> |
Observable.generate(Callable<S> initialState,
BiConsumer<S,Emitter<T>> generator,
Consumer<? super S> disposeState)
Returns a cold, synchronous and stateful generator of values.
|
static <T,S> Flowable<T> |
Flowable.generate(Callable<S> initialState,
BiFunction<S,Emitter<T>,S> generator,
Consumer<? super S> disposeState)
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
|
static <T,S> Observable<T> |
Observable.generate(Callable<S> initialState,
BiFunction<S,Emitter<T>,S> generator,
Consumer<? super S> disposeState)
Returns a cold, synchronous and stateful generator of values.
|
static <T> Flowable<T> |
Flowable.generate(Consumer<Emitter<T>> generator)
Returns a cold, synchronous, stateless and backpressure-aware generator of values.
|
static <T> Observable<T> |
Observable.generate(Consumer<Emitter<T>> generator)
Returns a cold, synchronous and stateless generator of values.
|
Flowable<T> |
Flowable.onBackpressureDrop(Consumer<? super T> onDrop)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to discard,
rather than emit, those items that its Subscriber is not prepared to observe.
|
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)
Subscribes to a Maybe and provides a callback to handle the items it emits.
|
Disposable |
Flowable.subscribe(Consumer<? super T> onNext)
Subscribes to a Publisher and provides a callback to handle the items it emits.
|
Disposable |
Single.subscribe(Consumer<? super T> onSuccess)
Subscribes to a Single and provides a callback to handle the item it emits.
|
Disposable |
Observable.subscribe(Consumer<? super T> onNext)
Subscribes to an ObservableSource and provides a callback to handle the items it emits.
|
Disposable |
Maybe.subscribe(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError)
Subscribes to a Maybe and provides callbacks to handle the items it emits and any error
notification it issues.
|
Disposable |
Maybe.subscribe(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError)
Subscribes to a Maybe and provides callbacks to handle the items it emits and any error
notification it issues.
|
Disposable |
Flowable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error
notification it issues.
|
Disposable |
Flowable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error
notification it issues.
|
Disposable |
Single.subscribe(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError)
Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it
issues.
|
Disposable |
Single.subscribe(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError)
Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it
issues.
|
Disposable |
Observable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to an ObservableSource and provides callbacks to handle the items it emits and any error
notification it issues.
|
Disposable |
Observable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to an ObservableSource and provides callbacks to handle the items it emits and any error
notification it issues.
|
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 |
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 |
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)
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 |
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 |
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.
|
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.
|
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.
|
static <T,D> Maybe<T> |
Maybe.using(Callable<? extends D> resourceSupplier,
Function<? super D,? extends MaybeSource<? extends T>> sourceSupplier,
Consumer<? super D> resourceDisposer)
Constructs a Maybe that creates a dependent resource object which is disposed of when the
upstream terminates or the downstream calls dispose().
|
static <T,D> Maybe<T> |
Maybe.using(Callable<? extends D> resourceSupplier,
Function<? super D,? extends MaybeSource<? extends T>> sourceSupplier,
Consumer<? super D> resourceDisposer,
boolean eager)
Constructs a Maybe that creates a dependent resource object which is disposed of just before
termination if you have set
disposeEagerly to true and a downstream dispose() does not occur
before termination. |
static <T,D> Observable<T> |
Observable.using(Callable<? extends D> resourceSupplier,
Function<? super D,? extends ObservableSource<? extends T>> sourceSupplier,
Consumer<? super D> disposer)
Constructs an ObservableSource that creates a dependent resource object which is disposed of when the downstream
calls dispose().
|
static <T,D> Observable<T> |
Observable.using(Callable<? extends D> resourceSupplier,
Function<? super D,? extends ObservableSource<? extends T>> sourceSupplier,
Consumer<? super D> disposer,
boolean eager)
Constructs an ObservableSource that creates a dependent resource object which is disposed of just before
termination if you have set
disposeEagerly to true and a dispose() call does not occur
before termination. |
static <T,D> Flowable<T> |
Flowable.using(Callable<? extends D> resourceSupplier,
Function<? super D,? extends org.reactivestreams.Publisher<? extends T>> sourceSupplier,
Consumer<? super D> resourceDisposer)
Constructs a Publisher that creates a dependent resource object which is disposed of on cancellation.
|
static <T,D> Flowable<T> |
Flowable.using(Callable<? extends D> resourceSupplier,
Function<? super D,? extends org.reactivestreams.Publisher<? extends T>> sourceSupplier,
Consumer<? super D> resourceDisposer,
boolean eager)
Constructs a Publisher that creates a dependent resource object which is disposed of just before
termination if you have set
disposeEagerly to true and cancellation does not occur
before termination. |
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 <T,U> Single<T> |
Single.using(Callable<U> resourceSupplier,
Function<? super U,? extends SingleSource<? extends T>> singleFunction,
Consumer<? super U> disposer)
Allows using and disposing a resource while running a SingleSource instance generated from
that resource (similar to a try-with-resources).
|
static <T,U> Single<T> |
Single.using(Callable<U> resourceSupplier,
Function<? super U,? extends SingleSource<? extends T>> singleFunction,
Consumer<? super U> disposer,
boolean eager)
Allows using and disposing a resource while running a SingleSource instance generated from
that resource (similar to a try-with-resources).
|
Modifier and Type | Method and Description |
---|---|
<K,V> Flowable<GroupedFlowable<K,V>> |
Flowable.groupBy(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector,
boolean delayError,
int bufferSize,
Function<? super Consumer<Object>,? extends Map<K,Object>> evictingMapFactory)
Groups the items emitted by a
Publisher according to a specified criterion, and emits these
grouped items as GroupedFlowable s. |
Modifier and Type | Method and Description |
---|---|
Flowable<T> |
ConnectableFlowable.autoConnect(int numberOfSubscribers,
Consumer<? super Disposable> connection)
Returns a Flowable that automatically connects (at most once) to this ConnectableFlowable
when the specified number of Subscribers subscribe to it and calls the
specified callback with the Subscription associated with the established connection.
|
abstract void |
ConnectableFlowable.connect(Consumer<? super Disposable> connection)
Instructs the
ConnectableFlowable to begin emitting the items from its underlying
Flowable to its Subscriber s. |
Modifier and Type | Class and Description |
---|---|
static class |
Functions.BoundedConsumer |
Modifier and Type | Field and Description |
---|---|
static Consumer<Throwable> |
Functions.ERROR_CONSUMER |
static Consumer<Throwable> |
Functions.ON_ERROR_MISSING
Wraps the consumed Throwable into an OnErrorNotImplementedException and
signals it to the plugin error handler.
|
static Consumer<org.reactivestreams.Subscription> |
Functions.REQUEST_MAX |
Modifier and Type | Method and Description |
---|---|
static <T> Consumer<T> |
Functions.actionConsumer(Action action) |
static <T> Consumer<T> |
Functions.boundedConsumer(int bufferSize) |
static <T> Consumer<T> |
Functions.emptyConsumer()
Returns an empty consumer that does nothing.
|
static <T> Consumer<Throwable> |
Functions.notificationOnError(Consumer<? super Notification<T>> onNotification) |
static <T> Consumer<T> |
Functions.notificationOnNext(Consumer<? super Notification<T>> onNotification) |
Modifier and Type | Method and Description |
---|---|
static <T> Action |
Functions.notificationOnComplete(Consumer<? super Notification<T>> onNotification) |
static <T> Consumer<Throwable> |
Functions.notificationOnError(Consumer<? super Notification<T>> onNotification) |
static <T> Consumer<T> |
Functions.notificationOnNext(Consumer<? super Notification<T>> onNotification) |
Modifier and Type | Class and Description |
---|---|
class |
CallbackCompletableObserver |
Constructor and Description |
---|
CallbackCompletableObserver(Consumer<? super Throwable> onError,
Action onComplete) |
ConsumerSingleObserver(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError) |
ConsumerSingleObserver(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError) |
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) |
LambdaObserver(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super Disposable> onSubscribe) |
LambdaObserver(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super Disposable> onSubscribe) |
Constructor and Description |
---|
CompletableDoOnEvent(CompletableSource source,
Consumer<? super Throwable> onEvent) |
CompletablePeek(CompletableSource source,
Consumer<? super Disposable> onSubscribe,
Consumer<? super Throwable> onError,
Action onComplete,
Action onTerminate,
Action onAfterTerminate,
Action onDispose) |
CompletablePeek(CompletableSource source,
Consumer<? super Disposable> onSubscribe,
Consumer<? super Throwable> onError,
Action onComplete,
Action onTerminate,
Action onAfterTerminate,
Action onDispose) |
CompletableUsing(Callable<R> resourceSupplier,
Function<? super R,? extends CompletableSource> completableFunction,
Consumer<? super R> disposer,
boolean eager) |
Modifier and Type | Class and Description |
---|---|
static class |
FlowableInternalHelper.RequestMax |
class |
FlowableOnBackpressureDrop<T> |
Modifier and Type | Method and Description |
---|---|
static <T> Consumer<Throwable> |
FlowableInternalHelper.subscriberOnError(org.reactivestreams.Subscriber<T> subscriber) |
static <T> Consumer<T> |
FlowableInternalHelper.subscriberOnNext(org.reactivestreams.Subscriber<T> subscriber) |
Modifier and Type | Method and Description |
---|---|
void |
FlowablePublish.connect(Consumer<? super Disposable> connection) |
void |
FlowableReplay.connect(Consumer<? super Disposable> connection) |
static <T,S> BiFunction<S,Emitter<T>,S> |
FlowableInternalHelper.simpleGenerator(Consumer<Emitter<T>> consumer) |
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)
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.
|
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 |
---|
FlowableAutoConnect(ConnectableFlowable<? extends T> source,
int numberOfSubscribers,
Consumer<? super Disposable> connection) |
FlowableDoAfterNext(Flowable<T> source,
Consumer<? super T> onAfterNext) |
FlowableDoOnEach(Flowable<T> source,
Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Action onAfterTerminate) |
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) |
FlowableGenerate(Callable<S> stateSupplier,
BiFunction<S,Emitter<T>,S> generator,
Consumer<? super S> disposeState) |
FlowableOnBackpressureDrop(Flowable<T> source,
Consumer<? super T> onDrop) |
FlowableUsing(Callable<? extends D> resourceSupplier,
Function<? super D,? extends org.reactivestreams.Publisher<? extends T>> sourceSupplier,
Consumer<? super D> disposer,
boolean eager) |
Constructor and Description |
---|
FlowableGroupBy(Flowable<T> source,
Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector,
int bufferSize,
boolean delayError,
Function<? super Consumer<Object>,? extends Map<K,Object>> mapFactory) |
Constructor and Description |
---|
MaybeCallbackObserver(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError,
Action onComplete) |
MaybeCallbackObserver(Consumer<? super T> onSuccess,
Consumer<? super Throwable> onError,
Action onComplete) |
MaybeDoAfterSuccess(MaybeSource<T> source,
Consumer<? super T> onAfterSuccess) |
MaybePeek(MaybeSource<T> source,
Consumer<? super Disposable> onSubscribeCall,
Consumer<? super T> onSuccessCall,
Consumer<? super Throwable> onErrorCall,
Action onCompleteCall,
Action onAfterTerminate,
Action onDispose) |
MaybePeek(MaybeSource<T> source,
Consumer<? super Disposable> onSubscribeCall,
Consumer<? super T> onSuccessCall,
Consumer<? super Throwable> onErrorCall,
Action onCompleteCall,
Action onAfterTerminate,
Action onDispose) |
MaybePeek(MaybeSource<T> source,
Consumer<? super Disposable> onSubscribeCall,
Consumer<? super T> onSuccessCall,
Consumer<? super Throwable> onErrorCall,
Action onCompleteCall,
Action onAfterTerminate,
Action onDispose) |
MaybeUsing(Callable<? extends D> resourceSupplier,
Function<? super D,? extends MaybeSource<? extends T>> sourceSupplier,
Consumer<? super D> resourceDisposer,
boolean eager) |
Modifier and Type | Method and Description |
---|---|
static <T> Consumer<Throwable> |
ObservableInternalHelper.observerOnError(Observer<T> observer) |
static <T> Consumer<T> |
ObservableInternalHelper.observerOnNext(Observer<T> observer) |
Modifier and Type | Method and Description |
---|---|
void |
ObservablePublish.connect(Consumer<? super Disposable> connection) |
void |
ObservableReplay.connect(Consumer<? super Disposable> connection) |
static <T,S> BiFunction<S,Emitter<T>,S> |
ObservableInternalHelper.simpleGenerator(Consumer<Emitter<T>> consumer) |
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.
|
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 |
---|
ObservableAutoConnect(ConnectableObservable<? extends T> source,
int numberOfObservers,
Consumer<? super Disposable> connection) |
ObservableDoAfterNext(ObservableSource<T> source,
Consumer<? super T> onAfterNext) |
ObservableDoOnEach(ObservableSource<T> source,
Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Action onAfterTerminate) |
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) |
ObservableGenerate(Callable<S> stateSupplier,
BiFunction<S,Emitter<T>,S> generator,
Consumer<? super S> disposeState) |
ObservableUsing(Callable<? extends D> resourceSupplier,
Function<? super D,? extends ObservableSource<? extends T>> sourceSupplier,
Consumer<? super D> disposer,
boolean eager) |
Constructor and Description |
---|
ParallelDoOnNextTry(ParallelFlowable<T> source,
Consumer<? super T> onNext,
BiFunction<? super Long,? super Throwable,ParallelFailureHandling> errorHandler) |
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) |
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) |
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) |
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 |
---|
SingleDoAfterSuccess(SingleSource<T> source,
Consumer<? super T> onAfterSuccess) |
SingleDoOnError(SingleSource<T> source,
Consumer<? super Throwable> onError) |
SingleDoOnSubscribe(SingleSource<T> source,
Consumer<? super Disposable> onSubscribe) |
SingleDoOnSuccess(SingleSource<T> source,
Consumer<? super T> onSuccess) |
SingleUsing(Callable<U> resourceSupplier,
Function<? super U,? extends SingleSource<? extends T>> singleFunction,
Consumer<? super U> disposer,
boolean eager) |
Constructor and Description |
---|
BoundedSubscriber(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super org.reactivestreams.Subscription> onSubscribe,
int bufferSize) |
BoundedSubscriber(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super org.reactivestreams.Subscription> onSubscribe,
int bufferSize) |
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) |
LambdaSubscriber(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super org.reactivestreams.Subscription> onSubscribe) |
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.
|
class |
ConnectConsumer
Store the Disposable received from the connection.
|
Modifier and Type | Method and Description |
---|---|
Observable<T> |
ConnectableObservable.autoConnect(int numberOfSubscribers,
Consumer<? super Disposable> connection)
Returns an Observable that automatically connects (at most once) to this ConnectableObservable
when the specified number of Subscribers subscribe to it and calls the
specified callback with the Subscription associated with the established connection.
|
abstract void |
ConnectableObservable.connect(Consumer<? super Disposable> connection)
Instructs the
ConnectableObservable to begin emitting the items from its underlying
Observable to its Observer s. |
Modifier and Type | Method and Description |
---|---|
TestObserver<T> |
TestObserver.assertOf(Consumer<? super TestObserver<T>> check)
Run a check consumer with this TestObserver instance.
|
Modifier and Type | Method and Description |
---|---|
ParallelFlowable<T> |
ParallelFlowable.doAfterNext(Consumer<? super T> onAfterNext)
Call the specified consumer with the current element passing through any 'rail'
after it has been delivered to downstream within the rail.
|
ParallelFlowable<T> |
ParallelFlowable.doOnError(Consumer<Throwable> onError)
Call the specified consumer with the exception passing through any 'rail'.
|
ParallelFlowable<T> |
ParallelFlowable.doOnNext(Consumer<? super T> onNext)
Call the specified consumer with the current element passing through any 'rail'.
|
ParallelFlowable<T> |
ParallelFlowable.doOnNext(Consumer<? super T> onNext,
BiFunction<? super Long,? super Throwable,ParallelFailureHandling> errorHandler)
Call the specified consumer with the current element passing through any 'rail' and
handles errors based on the returned value by the handler function.
|
ParallelFlowable<T> |
ParallelFlowable.doOnNext(Consumer<? super T> onNext,
ParallelFailureHandling errorHandler)
Call the specified consumer with the current element passing through any 'rail' and
handles errors based on the given
ParallelFailureHandling enumeration value. |
ParallelFlowable<T> |
ParallelFlowable.doOnSubscribe(Consumer<? super org.reactivestreams.Subscription> onSubscribe)
Call the specified callback when a 'rail' receives a Subscription from its upstream.
|
Modifier and Type | Method and Description |
---|---|
static Consumer<? super Throwable> |
RxJavaPlugins.getErrorHandler()
Returns the a hook consumer.
|
Modifier and Type | Method and Description |
---|---|
static void |
RxJavaPlugins.setErrorHandler(Consumer<? super Throwable> handler)
Sets the specific hook function.
|
Modifier and Type | Method and Description |
---|---|
TestSubscriber<T> |
TestSubscriber.assertOf(Consumer<? super TestSubscriber<T>> check)
Run a check consumer with this TestSubscriber instance.
|
Copyright © 2018 JBoss by Red Hat. All rights reserved.