T - the type of item expected to be observed and emitted by the Processorpublic final class BehaviorProcessor<T> extends FlowableProcessor<T>
Subscriber.
This processor does not have a public constructor by design; a new empty instance of this
BehaviorProcessor can be created via the create() method and
a new non-empty instance can be created via createDefault(Object) (named as such to avoid
overload resolution conflict with Flowable.create that creates a Flowable, not a BehaviorProcessor).
In accordance with the Reactive Streams specification (Rule 2.13)
nulls are not allowed as default initial values in createDefault(Object) or as parameters to onNext(Object) and
onError(Throwable).
When this BehaviorProcessor is terminated via onError(Throwable) or onComplete(), the
last observed item (if any) is cleared and late Subscribers only receive
the respective terminal event.
The BehaviorProcessor does not support clearing its cached value (to appear empty again), however, the
effect can be achieved by using a special item and making sure Subscribers subscribe through a
filter whose predicate filters out this special item:
BehaviorProcessor<Integer> processor = BehaviorProcessor.create();
final Integer EMPTY = Integer.MIN_VALUE;
Flowable<Integer> flowable = processor.filter(v -> v != EMPTY);
TestSubscriber<Integer> ts1 = flowable.test();
processor.onNext(1);
// this will "clear" the cache
processor.onNext(EMPTY);
TestSubscriber<Integer> ts2 = flowable.test();
processor.onNext(2);
processor.onComplete();
// ts1 received both non-empty items
ts1.assertResult(1, 2);
// ts2 received only 2 even though the current item was EMPTY
// when it got subscribed
ts2.assertResult(2);
// Subscribers coming after the processor was terminated receive
// no items and only the onComplete event in this case.
flowable.test().assertResult();
Even though BehaviorProcessor implements the Subscriber interface, calling
onSubscribe is not required (Rule 2.12)
if the processor is used as a standalone source. However, calling onSubscribe
after the BehaviorProcessor reached its terminal state will result in the
given Subscription being cancelled immediately.
Calling onNext(Object), offer(Object), onError(Throwable) and onComplete()
is required to be serialized (called from the same thread or called non-overlappingly from different threads
through external means of serialization). The FlowableProcessor.toSerialized() method available to all FlowableProcessors
provides such serialization and also protects against reentrance (i.e., when a downstream Subscriber
consuming this processor also wants to call onNext(Object) on this processor recursively).
Note that serializing over offer(Object) is not supported through toSerialized() because it is a method
available on the PublishProcessor and BehaviorProcessor classes only.
This BehaviorProcessor supports the standard state-peeking methods hasComplete(), hasThrowable(),
getThrowable() and hasSubscribers() as well as means to read the latest observed value
in a non-blocking and thread-safe manner via hasValue() or getValue().
Note that this processor signals MissingBackpressureException if a particular Subscriber is not
ready to receive onNext events. To avoid this exception being signaled, use offer(Object) to only
try to emit an item when all Subscribers have requested item(s).
BehaviorProcessor does not coordinate requests of its downstream Subscribers and
expects each individual Subscriber is ready to receive onNext items when onNext(Object)
is called. If a Subscriber is not ready, a MissingBackpressureException is signalled to it.
To avoid overflowing the current Subscribers, the conditional offer(Object) method is available
that returns true if any of the Subscribers is not ready to receive onNext events. If
there are no Subscribers to the processor, offer() always succeeds.
If the BehaviorProcessor is (optionally) subscribed to another Publisher, this upstream
Publisher is consumed in an unbounded fashion (requesting Long.MAX_VALUE).BehaviorProcessor does not operate by default on a particular Scheduler and
the Subscribers get notified on the thread the respective onXXX methods were invoked.onError(Throwable) is called, the BehaviorProcessor enters into a terminal state
and emits the same Throwable instance to the last set of Subscribers. During this emission,
if one or more Subscribers cancel their respective Subscriptions, the
Throwable is delivered to the global error handler via
RxJavaPlugins.onError(Throwable) (multiple times if multiple Subscribers
cancel at once).
If there were no Subscribers subscribed to this BehaviorProcessor when the onError()
was called, the global error handler is not invoked.
Example usage:
// subscriber will receive all events.
BehaviorProcessor<Object> processor = BehaviorProcessor.create("default");
processor.subscribe(subscriber);
processor.onNext("one");
processor.onNext("two");
processor.onNext("three");
// subscriber will receive the "one", "two" and "three" events, but not "zero"
BehaviorProcessor<Object> processor = BehaviorProcessor.create("default");
processor.onNext("zero");
processor.onNext("one");
processor.subscribe(subscriber);
processor.onNext("two");
processor.onNext("three");
// subscriber will receive only onComplete
BehaviorProcessor<Object> processor = BehaviorProcessor.create("default");
processor.onNext("zero");
processor.onNext("one");
processor.onComplete();
processor.subscribe(subscriber);
// subscriber will receive only onError
BehaviorProcessor<Object> processor = BehaviorProcessor.create("default");
processor.onNext("zero");
processor.onNext("one");
processor.onError(new RuntimeException("error"));
processor.subscribe(subscriber);
| Modifier and Type | Method and Description |
|---|---|
static <T> @NonNull BehaviorProcessor<T> |
create()
Creates a
BehaviorProcessor without a default item. |
static <T> @NonNull BehaviorProcessor<T> |
createDefault(T defaultValue)
Creates a
BehaviorProcessor that emits the last item it observed and all subsequent items to each
Subscriber that subscribes to it. |
@Nullable Throwable |
getThrowable()
Returns the error that caused the FlowableProcessor to terminate or null if the FlowableProcessor
hasn't terminated yet.
|
T |
getValue()
Returns a single value the BehaviorProcessor currently has or null if no such value exists.
|
boolean |
hasComplete()
Returns true if the FlowableProcessor has reached a terminal state through a complete event.
|
boolean |
hasSubscribers()
Returns true if the FlowableProcessor has subscribers.
|
boolean |
hasThrowable()
Returns true if the FlowableProcessor has reached a terminal state through an error event.
|
boolean |
hasValue()
Returns true if the BehaviorProcessor has any value.
|
boolean |
offer(T t)
Tries to emit the item to all currently subscribed Subscribers if all of them
has requested some value, returns false otherwise.
|
void |
onComplete() |
void |
onError(@NonNull Throwable t) |
void |
onNext(T t) |
void |
onSubscribe(@NonNull Subscription s)
Implementors of this method should make sure everything that needs
to be visible in
Subscriber.onNext(Object) is established before
calling Subscription.request(long). |
protected void |
subscribeActual(@NonNull Subscriber<? super T> s)
Operator implementations (both source and intermediate) should implement this method that
performs the necessary business logic and handles the incoming
Subscribers. |
toSerializedall, amb, ambArray, ambWith, any, blockingFirst, blockingFirst, blockingForEach, blockingForEach, blockingIterable, blockingIterable, blockingLast, blockingLast, blockingLatest, blockingMostRecent, blockingNext, blockingSingle, blockingSingle, blockingStream, blockingStream, blockingSubscribe, blockingSubscribe, blockingSubscribe, blockingSubscribe, blockingSubscribe, blockingSubscribe, blockingSubscribe, blockingSubscribe, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, bufferSize, cache, cacheWithInitialCapacity, cast, collect, collect, collectInto, combineLatest, combineLatest, combineLatest, combineLatest, combineLatest, combineLatest, combineLatest, combineLatest, combineLatest, combineLatest, combineLatestArray, combineLatestArray, combineLatestArrayDelayError, combineLatestArrayDelayError, combineLatestDelayError, combineLatestDelayError, compose, concat, concat, concat, concat, concat, concat, concatArray, concatArrayDelayError, concatArrayEager, concatArrayEager, concatArrayEagerDelayError, concatArrayEagerDelayError, concatDelayError, concatDelayError, concatDelayError, concatEager, concatEager, concatEager, concatEager, concatEagerDelayError, concatEagerDelayError, concatEagerDelayError, concatEagerDelayError, concatMap, concatMap, concatMap, concatMapCompletable, concatMapCompletable, concatMapCompletableDelayError, concatMapCompletableDelayError, concatMapCompletableDelayError, concatMapDelayError, concatMapDelayError, concatMapDelayError, concatMapEager, concatMapEager, concatMapEagerDelayError, concatMapEagerDelayError, concatMapIterable, concatMapIterable, concatMapMaybe, concatMapMaybe, concatMapMaybeDelayError, concatMapMaybeDelayError, concatMapMaybeDelayError, concatMapSingle, concatMapSingle, concatMapSingleDelayError, concatMapSingleDelayError, concatMapSingleDelayError, concatMapStream, concatMapStream, concatWith, concatWith, concatWith, concatWith, contains, count, create, debounce, debounce, debounce, defaultIfEmpty, defer, delay, delay, delay, delay, delay, delay, delaySubscription, delaySubscription, delaySubscription, dematerialize, distinct, distinct, distinct, distinctUntilChanged, distinctUntilChanged, distinctUntilChanged, doAfterNext, doAfterTerminate, doFinally, doOnCancel, doOnComplete, doOnEach, doOnEach, doOnError, doOnLifecycle, doOnNext, doOnRequest, doOnSubscribe, doOnTerminate, elementAt, elementAt, elementAtOrError, empty, error, error, filter, first, firstElement, firstOrError, firstOrErrorStage, firstStage, flatMap, flatMap, flatMap, flatMap, flatMap, flatMap, flatMap, flatMap, flatMap, flatMap, flatMap, flatMap, flatMapCompletable, flatMapCompletable, flatMapIterable, flatMapIterable, flatMapIterable, flatMapIterable, flatMapMaybe, flatMapMaybe, flatMapSingle, flatMapSingle, flatMapStream, flatMapStream, forEach, forEachWhile, forEachWhile, forEachWhile, fromAction, fromArray, fromCallable, fromCompletable, fromCompletionStage, fromFuture, fromFuture, fromIterable, fromMaybe, fromObservable, fromOptional, fromPublisher, fromRunnable, fromSingle, fromStream, fromSupplier, generate, generate, generate, generate, generate, groupBy, groupBy, groupBy, groupBy, groupBy, groupBy, groupJoin, hide, ignoreElements, interval, interval, interval, interval, intervalRange, intervalRange, isEmpty, join, just, just, just, just, just, just, just, just, just, just, last, lastElement, lastOrError, lastOrErrorStage, lastStage, lift, map, mapOptional, materialize, merge, merge, merge, merge, merge, merge, merge, merge, mergeArray, mergeArray, mergeArrayDelayError, mergeArrayDelayError, mergeDelayError, mergeDelayError, mergeDelayError, mergeDelayError, mergeDelayError, mergeDelayError, mergeDelayError, mergeDelayError, mergeWith, mergeWith, mergeWith, mergeWith, never, observeOn, observeOn, observeOn, ofType, onBackpressureBuffer, onBackpressureBuffer, onBackpressureBuffer, onBackpressureBuffer, onBackpressureBuffer, onBackpressureBuffer, onBackpressureBuffer, onBackpressureBuffer, onBackpressureDrop, onBackpressureDrop, onBackpressureLatest, onErrorComplete, onErrorComplete, onErrorResumeNext, onErrorResumeWith, onErrorReturn, onErrorReturnItem, onTerminateDetach, parallel, parallel, parallel, publish, publish, publish, publish, range, rangeLong, rebatchRequests, reduce, reduce, reduceWith, repeat, repeat, repeatUntil, repeatWhen, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, replay, retry, retry, retry, retry, retry, retryUntil, retryWhen, safeSubscribe, sample, sample, sample, sample, sample, sample, scan, scan, scanWith, sequenceEqual, sequenceEqual, sequenceEqual, sequenceEqual, serialize, share, single, singleElement, singleOrError, singleOrErrorStage, singleStage, skip, skip, skip, skipLast, skipLast, skipLast, skipLast, skipLast, skipLast, skipUntil, skipWhile, sorted, sorted, startWith, startWith, startWith, startWith, startWithArray, startWithItem, startWithIterable, subscribe, subscribe, subscribe, subscribe, subscribe, subscribe, subscribeOn, subscribeOn, subscribeWith, switchIfEmpty, switchMap, switchMap, switchMapCompletable, switchMapCompletableDelayError, switchMapDelayError, switchMapDelayError, switchMapMaybe, switchMapMaybeDelayError, switchMapSingle, switchMapSingleDelayError, switchOnNext, switchOnNext, switchOnNextDelayError, switchOnNextDelayError, take, take, take, takeLast, takeLast, takeLast, takeLast, takeLast, takeLast, takeLast, takeLast, takeLast, takeUntil, takeUntil, takeWhile, test, test, test, throttleFirst, throttleFirst, throttleLast, throttleLast, throttleLatest, throttleLatest, throttleLatest, throttleLatest, throttleWithTimeout, throttleWithTimeout, timeInterval, timeInterval, timeInterval, timeInterval, timeout, timeout, timeout, timeout, timeout, timeout, timeout, timeout, timer, timer, timestamp, timestamp, timestamp, timestamp, to, toFuture, toList, toList, toList, toMap, toMap, toMap, toMultimap, toMultimap, toMultimap, toMultimap, toObservable, toSortedList, toSortedList, toSortedList, toSortedList, unsafeCreate, unsubscribeOn, using, using, window, window, window, window, window, window, window, window, window, window, window, window, window, window, window, window, window, withLatestFrom, withLatestFrom, withLatestFrom, withLatestFrom, withLatestFrom, withLatestFrom, zip, zip, zip, zip, zip, zip, zip, zip, zip, zip, zip, zip, zipArray, zipWith, zipWith, zipWith, zipWith@CheckReturnValue @NonNull public static <T> @NonNull BehaviorProcessor<T> create()
BehaviorProcessor without a default item.T - the type of item the BehaviorProcessor will emitBehaviorProcessor@CheckReturnValue @NonNull public static <T> @NonNull BehaviorProcessor<T> createDefault(T defaultValue)
BehaviorProcessor that emits the last item it observed and all subsequent items to each
Subscriber that subscribes to it.T - the type of item the BehaviorProcessor will emitdefaultValue - the item that will be emitted first to any Subscriber as long as the
BehaviorProcessor has not yet observed any items from its source ObservableBehaviorProcessorNullPointerException - if defaultValue is nullprotected void subscribeActual(@NonNull @NonNull Subscriber<? super T> s)
FlowableSubscribers.
There is no need to call any of the plugin hooks on the current Flowable instance or
the Subscriber; all hooks and basic safeguards have been
applied by Flowable.subscribe(Subscriber) before this method gets called.
subscribeActual in class Flowable<T>s - the incoming Subscriber, never nullpublic void onSubscribe(@NonNull @NonNull Subscription s)
FlowableSubscriberSubscriber.onNext(Object) is established before
calling Subscription.request(long). In practice this means
no initialization should happen after the request() call and
additional behavior is thread safe in respect to onNext.
public void onComplete()
@CheckReturnValue public boolean offer(@NonNull T t)
This method should be called in a sequential manner just like the onXXX methods of the PublishProcessor.
Calling with a null value will terminate the PublishProcessor and a NullPointerException is signaled to the Subscribers.
History: 2.0.8 - experimental
t - the item to emit, not nullNullPointerException - if t is null@CheckReturnValue public boolean hasSubscribers()
FlowableProcessorThe method is thread-safe.
hasSubscribers in class FlowableProcessor<T>@Nullable @CheckReturnValue public @Nullable Throwable getThrowable()
FlowableProcessorThe method is thread-safe.
getThrowable in class FlowableProcessor<T>@Nullable @CheckReturnValue public T getValue()
The method is thread-safe.
@CheckReturnValue public boolean hasComplete()
FlowableProcessorThe method is thread-safe.
hasComplete in class FlowableProcessor<T>FlowableProcessor.hasThrowable()@CheckReturnValue public boolean hasThrowable()
FlowableProcessorThe method is thread-safe.
hasThrowable in class FlowableProcessor<T>FlowableProcessor.getThrowable(),
FlowableProcessor.hasComplete()@CheckReturnValue public boolean hasValue()
The method is thread-safe.