T
- the input and output value typepublic final class DispatchWorkProcessor<T> extends FlowableProcessor<T> implements Disposable
FlowableProcessor
variant that queues up items and dispatches them asynchronously
so that one of the currently subscribed Subscriber
s can pick it up one by
one, otherwise* cache it until at least an Subscriber
subscribes.Modifier and Type | Method and Description |
---|---|
static <T> DispatchWorkProcessor<T> |
create(Scheduler scheduler)
Create an empty
DispatchWorkProcessor instance with the given scheduler,
default capacity hint (Flowable.bufferSize() , expected number of items
cached until consumption) and delaying errors. |
static <T> DispatchWorkProcessor<T> |
create(Scheduler scheduler,
boolean delayErrors)
Create an empty
DispatchWorkProcessor instance with the given scheduler,
default capacity hint (Flowable.bufferSize() , expected number of items
cached until consumption) and if an error should be delayed. |
static <T> DispatchWorkProcessor<T> |
create(Scheduler scheduler,
int capacityHint)
Create an empty
DispatchWorkProcessor instance with the given scheduler,
capacity hint (expected number of items cached until consumption) and delaying
errors. |
static <T> DispatchWorkProcessor<T> |
create(Scheduler scheduler,
int capacityHint,
boolean delayErrors)
Create an empty
DispatchWorkProcessor instance with the given scheduler,
capacity hint (expected number of items cached until consumption) and if an
error should be delayed. |
static <T> DispatchWorkProcessor<T> |
createUnbounded(Scheduler scheduler)
Create an empty, unbounded
DispatchWorkProcessor instance with the given scheduler,
default capacity hint (Flowable.bufferSize() , expected number of items
cached until consumption) and delaying errors. |
static <T> DispatchWorkProcessor<T> |
createUnbounded(Scheduler scheduler,
int capacityHint,
boolean delayErrors)
Create an empty and unbounded
DispatchWorkProcessor instance with the given scheduler,
capacity hint (expected number of items cached until consumption) and if an
error should be delayed. |
void |
dispose() |
Throwable |
getThrowable() |
boolean |
hasComplete() |
boolean |
hasSubscribers() |
boolean |
hasThrowable() |
boolean |
isDisposed() |
void |
onComplete() |
void |
onError(Throwable e) |
void |
onNext(T t) |
void |
onSubscribe(Subscription s) |
protected void |
subscribeActual(Subscriber<? super T> subscriber) |
toSerialized
all, 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, 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, onBackpressureReduce, onBackpressureReduce, 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, 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, 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, throttleFirst, throttleLast, throttleLast, throttleLast, throttleLatest, throttleLatest, throttleLatest, throttleLatest, throttleLatest, throttleWithTimeout, 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
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
disposed, empty, fromAction, fromAutoCloseable, fromFuture, fromFuture, fromRunnable, fromSubscription, toAutoCloseable
public static <T> DispatchWorkProcessor<T> create(Scheduler scheduler)
DispatchWorkProcessor
instance with the given scheduler,
default capacity hint (Flowable.bufferSize()
, expected number of items
cached until consumption) and delaying errors.T
- the input and output value typescheduler
- the scheduler to use for the Observer
s to be notified onpublic static <T> DispatchWorkProcessor<T> createUnbounded(Scheduler scheduler)
DispatchWorkProcessor
instance with the given scheduler,
default capacity hint (Flowable.bufferSize()
, expected number of items
cached until consumption) and delaying errors.T
- the input and output value typescheduler
- the scheduler to use for the Observer
s to be notified onpublic static <T> DispatchWorkProcessor<T> create(Scheduler scheduler, int capacityHint)
DispatchWorkProcessor
instance with the given scheduler,
capacity hint (expected number of items cached until consumption) and delaying
errors.T
- the input and output value typescheduler
- the scheduler to use for the Observer
s to be notified oncapacityHint
- the expected number of items to be cached until consumptionpublic static <T> DispatchWorkProcessor<T> create(Scheduler scheduler, boolean delayErrors)
DispatchWorkProcessor
instance with the given scheduler,
default capacity hint (Flowable.bufferSize()
, expected number of items
cached until consumption) and if an error should be delayed.T
- the input and output value typescheduler
- the scheduler to use for the Observer
s to be notified ondelayErrors
- if true, errors are delivered after items have been consumedpublic static <T> DispatchWorkProcessor<T> create(Scheduler scheduler, int capacityHint, boolean delayErrors)
DispatchWorkProcessor
instance with the given scheduler,
capacity hint (expected number of items cached until consumption) and if an
error should be delayed.T
- the input and output value typescheduler
- the scheduler to use for the Observer
s to be notified oncapacityHint
- the expected number of items to be cached until consumptiondelayErrors
- if true, errors are delivered after items have been consumedpublic static <T> DispatchWorkProcessor<T> createUnbounded(Scheduler scheduler, int capacityHint, boolean delayErrors)
DispatchWorkProcessor
instance with the given scheduler,
capacity hint (expected number of items cached until consumption) and if an
error should be delayed.T
- the input and output value typescheduler
- the scheduler to use for the Observer
s to be notified oncapacityHint
- the expected number of items to be cached until consumptiondelayErrors
- if true, errors are delivered after items have been consumedpublic void onSubscribe(Subscription s)
onSubscribe
in interface FlowableSubscriber<T>
onSubscribe
in interface Subscriber<T>
public void onNext(T t)
onNext
in interface Subscriber<T>
public void onError(Throwable e)
onError
in interface Subscriber<T>
public void onComplete()
onComplete
in interface Subscriber<T>
protected void subscribeActual(Subscriber<? super T> subscriber)
subscribeActual
in class Flowable<T>
public void dispose()
dispose
in interface Disposable
public boolean isDisposed()
isDisposed
in interface Disposable
public boolean hasComplete()
hasComplete
in class FlowableProcessor<T>
public boolean hasThrowable()
hasThrowable
in class FlowableProcessor<T>
public Throwable getThrowable()
getThrowable
in class FlowableProcessor<T>
public boolean hasSubscribers()
hasSubscribers
in class FlowableProcessor<T>