public abstract class BatchAction<T,V> extends Action<T,V>
Modifier and Type | Field and Description |
---|---|
protected int |
batchSize |
protected reactor.core.Dispatcher |
dispatcher |
protected boolean |
first |
protected boolean |
flush |
protected reactor.fn.Consumer<T> |
flushConsumer |
protected int |
index |
protected boolean |
next |
protected reactor.fn.timer.Timer |
timer |
protected long |
timespan |
protected java.util.concurrent.TimeUnit |
unit |
capacity, downstreamSubscription, NO_CAPACITY, RESERVED_SLOTS, upstreamSubscription
Constructor and Description |
---|
BatchAction(reactor.core.Dispatcher dispatcher,
int batchSize,
boolean next,
boolean first,
boolean flush) |
BatchAction(reactor.core.Dispatcher dispatcher,
int batchSize,
boolean next,
boolean first,
boolean flush,
long timespan,
java.util.concurrent.TimeUnit unit,
reactor.fn.timer.Timer timer) |
Modifier and Type | Method and Description |
---|---|
protected PushSubscription<T> |
createTrackingSubscription(org.reactivestreams.Subscription subscription) |
protected void |
doComplete() |
protected void |
doNext(T value) |
protected void |
firstCallback(T event) |
protected void |
flushCallback(T event) |
reactor.core.Dispatcher |
getDispatcher()
Get the dispatcher used to execute signals on this Stream instance.
|
boolean |
isReactivePull(reactor.core.Dispatcher dispatcher,
long producerCapacity) |
protected void |
nextCallback(T event) |
java.lang.String |
toString() |
accept, addSubscription, broadcastComplete, broadcastError, broadcastNext, cancel, cancelSubscription, capacity, checkRequest, combine, control, createSubscription, createSubscription, debug, doError, doOnSubscribe, doShutdown, doStart, downstreamSubscription, evaluateCapacity, findOldestUpstream, getCapacity, getSubscription, isPublishing, onComplete, onError, onNext, onOverflowBuffer, onSubscribe, recycle, requestAll, requestMore, requestUpstream, subscribe, subscribeWithSubscription, toBroadcastCompleteConsumer, toBroadcastErrorConsumer, toBroadcastNextConsumer
adaptiveConsume, adaptiveConsumeOn, after, batchConsume, batchConsumeOn, broadcast, broadcastOn, broadcastTo, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, buffer, cache, cast, concatMap, concatWith, consume, consume, consume, consume, consume, consumeLater, consumeOn, consumeOn, consumeOn, count, count, decode, defaultIfEmpty, dematerialize, dispatchOn, dispatchOn, dispatchOn, distinct, distinct, distinctUntilChanged, distinctUntilChanged, elapsed, elementAt, elementAtOrDefault, encode, env, exists, fanIn, filter, filter, finallyDo, flatMap, getEnvironment, getTimer, groupBy, ignoreError, ignoreError, join, joinWith, keepAlive, last, lift, log, log, map, materialize, merge, mergeWith, nest, next, observe, observeCancel, observeComplete, observeError, observeStart, observeSubscribe, onErrorResumeNext, onErrorResumeNext, onErrorReturn, onErrorReturn, onOverflowBuffer, onOverflowDrop, partition, partition, process, recover, reduce, reduce, repeat, repeat, repeatWhen, requestWhen, retry, retry, retry, retry, retryWhen, sample, sample, sample, sample, sample, sample, sampleFirst, sampleFirst, sampleFirst, sampleFirst, sampleFirst, sampleFirst, scan, scan, skip, skip, skip, skipWhile, skipWhile, sort, sort, sort, sort, split, split, startWith, startWith, startWith, subscribe, subscribeOn, subscribeOn, subscribeOn, switchMap, take, take, take, takeWhile, tap, throttle, throttle, timeout, timeout, timeout, timeout, timestamp, toBlockingQueue, toBlockingQueue, toList, toList, unbounded, when, window, window, window, window, window, window, window, window, window, window, window, zip, zipWith, zipWith
protected final boolean next
protected final boolean flush
protected final boolean first
protected final int batchSize
protected final reactor.core.Dispatcher dispatcher
protected final long timespan
protected final java.util.concurrent.TimeUnit unit
protected final reactor.fn.timer.Timer timer
protected final reactor.fn.Consumer<T> flushConsumer
protected int index
public BatchAction(reactor.core.Dispatcher dispatcher, int batchSize, boolean next, boolean first, boolean flush)
public BatchAction(reactor.core.Dispatcher dispatcher, int batchSize, boolean next, boolean first, boolean flush, long timespan, java.util.concurrent.TimeUnit unit, reactor.fn.timer.Timer timer)
protected PushSubscription<T> createTrackingSubscription(org.reactivestreams.Subscription subscription)
createTrackingSubscription
in class Action<T,V>
public boolean isReactivePull(reactor.core.Dispatcher dispatcher, long producerCapacity)
isReactivePull
in interface reactor.core.support.NonBlocking
isReactivePull
in class Stream<V>
protected void nextCallback(T event)
protected void flushCallback(T event)
protected void firstCallback(T event)
protected void doComplete()
doComplete
in class Action<T,V>
public final reactor.core.Dispatcher getDispatcher()
Stream
getDispatcher
in class Stream<V>