T - the value type received and emitted by this Processor subclasspublic final class UnicastProcessor<T> extends FlowableProcessor<T>
FlowableProcessor variant that queues up events until a single Subscriber subscribes to it, replays
those events to it until the Subscriber catches up and then switches to relaying events live to
this single Subscriber until this UnicastProcessor terminates or the Subscriber cancels
its subscription.
This processor does not have a public constructor by design; a new empty instance of this
UnicastProcessor can be created via the following create methods that
allow specifying the retention policy for items:
create() - creates an empty, unbounded UnicastProcessor that
caches all items and the terminal event it receives.create(int) - creates an empty, unbounded UnicastProcessor
with a hint about how many total items one expects to retain.create(boolean) - creates an empty, unbounded UnicastProcessor that
optionally delays an error it receives and replays it after the regular items have been emitted.create(int, Runnable) - creates an empty, unbounded UnicastProcessor
with a hint about how many total items one expects to retain and a callback that will be
called exactly once when the UnicastProcessor gets terminated or the single Subscriber cancels.create(int, Runnable, boolean) - creates an empty, unbounded UnicastProcessor
with a hint about how many total items one expects to retain and a callback that will be
called exactly once when the UnicastProcessor gets terminated or the single Subscriber cancels
and optionally delays an error it receives and replays it after the regular items have been emitted.
If more than one Subscriber attempts to subscribe to this Processor, they
will receive an IllegalStateException if this UnicastProcessor hasn't terminated yet,
or the Subscribers receive the terminal event (error or completion) if this
Processor has terminated.
The UnicastProcessor buffers notifications and replays them to the single Subscriber as requested,
for which it holds upstream items an unbounded internal buffer until they can be emitted.
Since a UnicastProcessor is a Reactive Streams Processor,
nulls are not allowed (Rule 2.13) as
parameters to onNext(Object) and onError(Throwable). Such calls will result in a
NullPointerException being thrown and the processor's state is not changed.
Since a UnicastProcessor is a Flowable as well as a FlowableProcessor, it
honors the downstream backpressure but consumes an upstream source in an unbounded manner (requesting Long.MAX_VALUE).
When this UnicastProcessor is terminated via onError(Throwable) the current or late single Subscriber
may receive the Throwable before any available items could be emitted. To make sure an onError event is delivered
to the Subscriber after the normal items, create a UnicastProcessor with the create(boolean) or
create(int, Runnable, boolean) factory methods.
Even though UnicastProcessor 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 UnicastProcessor reached its terminal state will result in the
given Subscription being canceled immediately.
Calling onNext(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).
This UnicastProcessor supports the standard state-peeking methods hasComplete(), hasThrowable(),
getThrowable() and hasSubscribers().
UnicastProcessor honors the downstream backpressure but consumes an upstream source
(if any) in an unbounded manner (requesting Long.MAX_VALUE).UnicastProcessor does not operate by default on a particular Scheduler and
the single Subscriber gets notified on the thread the respective onXXX methods were invoked.onError(Throwable) is called, the UnicastProcessor enters into a terminal state
and emits the same Throwable instance to the current single Subscriber. During this emission,
if the single Subscribers cancels its respective Subscriptions, the
Throwable is delivered to the global error handler via
RxJavaPlugins.onError(Throwable).
If there were no Subscribers subscribed to this UnicastProcessor when the onError()
was called, the global error handler is not invoked.
Example usage:
UnicastProcessor<Integer> processor = UnicastProcessor.create();
TestSubscriber<Integer> ts1 = processor.test();
// fresh UnicastProcessors are empty
ts1.assertEmpty();
TestSubscriber<Integer> ts2 = processor.test();
// A UnicastProcessor only allows one Subscriber during its lifetime
ts2.assertFailure(IllegalStateException.class);
processor.onNext(1);
ts1.assertValue(1);
processor.onNext(2);
ts1.assertValues(1, 2);
processor.onComplete();
ts1.assertResult(1, 2);
// ----------------------------------------------------
UnicastProcessor<Integer> processor2 = UnicastProcessor.create();
// a UnicastProcessor caches events until its single Subscriber subscribes
processor2.onNext(1);
processor2.onNext(2);
processor2.onComplete();
TestSubscriber<Integer> ts3 = processor2.test();
// the cached events are emitted in order
ts3.assertResult(1, 2);
| Modifier and Type | Method and Description |
|---|---|
static <T> @NonNull UnicastProcessor<T> |
create()
Creates an UnicastSubject with an internal buffer capacity hint 16.
|
static <T> @NonNull UnicastProcessor<T> |
create(boolean delayError)
Creates an UnicastProcessor with default internal buffer capacity hint and delay error flag.
|
static <T> @NonNull UnicastProcessor<T> |
create(int capacityHint)
Creates an UnicastProcessor with the given internal buffer capacity hint.
|
static <T> @NonNull UnicastProcessor<T> |
create(int capacityHint,
@NonNull Runnable onTerminate)
Creates an UnicastProcessor with the given internal buffer capacity hint and a callback for
the case when the single Subscriber cancels its subscription or the
processor is terminated.
|
static <T> @NonNull UnicastProcessor<T> |
create(int capacityHint,
@NonNull Runnable onTerminate,
boolean delayError)
Creates an UnicastProcessor with the given internal buffer capacity hint, delay error flag and a callback for
the case when the single Subscriber cancels its subscription or
the processor is terminated.
|
@Nullable Throwable |
getThrowable()
Returns the error that caused the FlowableProcessor to terminate or null if the FlowableProcessor
hasn't terminated yet.
|
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.
|
void |
onComplete() |
void |
onError(Throwable t) |
void |
onNext(T t) |
void |
onSubscribe(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(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 UnicastProcessor<T> create()
T - the value type@CheckReturnValue @NonNull public static <T> @NonNull UnicastProcessor<T> create(int capacityHint)
T - the value typecapacityHint - the hint to size the internal unbounded bufferIllegalArgumentException - if capacityHint is non-positive@CheckReturnValue @NonNull public static <T> @NonNull UnicastProcessor<T> create(boolean delayError)
History: 2.0.8 - experimental
T - the value typedelayError - deliver pending onNext events before onError@CheckReturnValue @NonNull public static <T> @NonNull UnicastProcessor<T> create(int capacityHint, @NonNull @NonNull Runnable onTerminate)
The callback, if not null, is called exactly once and non-overlapped with any active replay.
T - the value typecapacityHint - the hint to size the internal unbounded bufferonTerminate - the non null callbackNullPointerException - if onTerminate is nullIllegalArgumentException - if capacityHint is non-positive@CheckReturnValue @NonNull public static <T> @NonNull UnicastProcessor<T> create(int capacityHint, @NonNull @NonNull Runnable onTerminate, boolean delayError)
The callback, if not null, is called exactly once and non-overlapped with any active replay.
History: 2.0.8 - experimental
T - the value typecapacityHint - the hint to size the internal unbounded bufferonTerminate - the non null callbackdelayError - deliver pending onNext events before onErrorNullPointerException - if onTerminate is nullIllegalArgumentException - if capacityHint is non-positivepublic void onSubscribe(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 onNext(T t)
public void onError(Throwable t)
public void onComplete()
protected void subscribeActual(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 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>@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()