- cache() - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a hot source and cache last emitted signals for further  Subscriber. 
- cache(int) - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a hot source and cache last emitted signals for further  Subscriber. 
- cache(Duration) - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a hot source and cache last emitted signals for further
  Subscriber. 
- cache(int, Duration) - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a hot source and cache last emitted signals for further
  Subscriber. 
- cache() - Method in class reactor.core.publisher.Mono
- 
Turn this  Mono into a hot source and cache last emitted signals for further  Subscriber. 
- cacheLast() - Static method in class reactor.core.publisher.ReplayProcessor
- 
- cacheLastOrDefault(T) - Static method in class reactor.core.publisher.ReplayProcessor
- 
- call() - Method in interface reactor.core.Fuseable.ScalarCallable
-  
- cancel() - Method in class reactor.core.publisher.BaseSubscriber
-  
- cancel() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- cancel() - Method in class reactor.core.publisher.MonoProcessor
-  
- cancel() - Method in class reactor.core.publisher.Operators.DeferredSubscription
-  
- cancel() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- cancel() - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- cancel() - Method in class reactor.core.publisher.UnicastProcessor
-  
- CANCEL_STACKTRACE - Static variable in class reactor.core.Exceptions
- 
- Cancellation - Interface in reactor.core
- 
- cancelledSubscription() - Static method in class reactor.core.publisher.Operators
- 
A singleton Subscription that represents a cancelled subscription instance and
 should not be leaked to clients as it represents a terminal state. 
- cancelOn(Scheduler) - Method in class reactor.core.publisher.Flux
- 
Prepare this  Flux so that subscribers will cancel from it on a
 specified
  Scheduler. 
- cancelOn(Scheduler) - Method in class reactor.core.publisher.Mono
- 
Prepare this  Mono so that subscribers will cancel from it on a
 specified
  Scheduler. 
- cast(Class<E>) - Method in class reactor.core.publisher.Flux
- 
Cast the current  Flux produced type into a target produced type. 
- cast(Class<E>) - Method in class reactor.core.publisher.Mono
- 
Cast the current  Mono produced type into a target produced type. 
- ceilingNextPowerOfTwo(int) - Static method in class reactor.util.concurrent.QueueSupplier
- 
Calculate the next power of 2, greater than or equal to x. 
- checkpoint() - Method in class reactor.core.publisher.Flux
- 
Activate assembly tracing for this particular  Flux, in case of an error
 upstream of the checkpoint. 
- checkpoint(String) - Method in class reactor.core.publisher.Flux
- 
Activate assembly tracing for this particular  Flux and give it
 a description that will be reflected in the assembly traceback in case
 of an error upstream of the checkpoint. 
- checkpoint() - Method in class reactor.core.publisher.Mono
- 
Activate assembly tracing for this particular  Mono, in case of an error
 upstream of the checkpoint. 
- checkpoint(String) - Method in class reactor.core.publisher.Mono
- 
Activate assembly tracing for this particular  Mono and give it
 a description that will be reflected in the assembly traceback, in case of an error
 upstream of the checkpoint. 
- checkpoint() - Method in class reactor.core.publisher.ParallelFlux
- 
Activate assembly tracing for this particular  ParallelFlux, in case of an
 error upstream of the checkpoint. 
- checkpoint(String) - Method in class reactor.core.publisher.ParallelFlux
- 
Activate assembly tracing for this particular  ParallelFlux and give it
 a description that will be reflected in the assembly traceback, in case of an error
 upstream of the checkpoint. 
- checkRequest(long) - Static method in class reactor.core.publisher.Operators
- 
Throws an exception if request is 0 or negative as specified in rule 3.09 of Reactive Streams 
- checkRequest(long, Subscriber<?>) - Static method in class reactor.core.publisher.Operators
- 
Throws an exception if request is 0 or negative as specified in rule 3.09 of Reactive Streams 
- clear() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- clear() - Method in class reactor.core.publisher.UnicastProcessor
-  
- clear(Consumer<? super T>) - Method in class reactor.util.concurrent.OpenHashSet
-  
- close() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- collect(Supplier<E>, BiConsumer<E, ? super T>) - Method in class reactor.core.publisher.Flux
- 
Collect the  Flux sequence with the given collector and supplied container on subscribe. 
- collect(Collector<? super T, A, ? extends R>) - Method in class reactor.core.publisher.Flux
- 
Collect the  Flux sequence with the given collector and supplied container on subscribe. 
- collect(Supplier<? extends C>, BiConsumer<? super C, ? super T>) - Method in class reactor.core.publisher.ParallelFlux
- 
Collect the elements in each rail into a collection supplied via a
 collectionSupplier and collected into with a collector action, emitting the
 collection at the end. 
- collectList() - Method in class reactor.core.publisher.Flux
- 
Accumulate this  Flux sequence in a  List that is emitted to the returned  Mono on
 onComplete. 
- collectMap(Function<? super T, ? extends K>) - Method in class reactor.core.publisher.Flux
- 
Convert all this
  Flux sequence into a hashed map where the key is extracted by the given  Function and the
 value will be the most recent emitted item for this key. 
- collectMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
- 
Convert all this  Flux sequence into a hashed map where the key is extracted by the given function and the value will be
 the most recent extracted item for this key. 
- collectMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<Map<K, V>>) - Method in class reactor.core.publisher.Flux
- 
Convert all this  Flux sequence into a supplied map where the key is extracted by the given function and the value will
 be the most recent extracted item for this key. 
- collectMultimap(Function<? super T, ? extends K>) - Method in class reactor.core.publisher.Flux
- 
Convert this  Flux sequence into a hashed map where the key is extracted by the given function and the value will be
 all the emitted item for this key. 
- collectMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
- 
Convert this  Flux sequence into a hashed map where the key is extracted by the given function and the value will be
 all the extracted items for this key. 
- collectMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<Map<K, Collection<V>>>) - Method in class reactor.core.publisher.Flux
- 
Convert this  Flux sequence into a supplied map where the key is extracted by the given function and the value will
 be all the extracted items for this key. 
- collectSortedList() - Method in class reactor.core.publisher.Flux
- 
Accumulate and sort this  Flux sequence in a  List that is emitted to the returned  Mono on
 onComplete. 
- collectSortedList(Comparator<? super T>) - Method in class reactor.core.publisher.Flux
- 
Accumulate and sort using the given comparator this
  Flux sequence in a  List that is emitted to the returned  Mono on
 onComplete. 
- collectSortedList(Comparator<? super T>) - Method in class reactor.core.publisher.ParallelFlux
- 
Sorts the 'rails' according to the comparator and returns a full sorted list as a
 Publisher. 
- collectSortedList(Comparator<? super T>, int) - Method in class reactor.core.publisher.ParallelFlux
- 
Sorts the 'rails' according to the comparator and returns a full sorted list as a
 Publisher. 
- combineLatest(Function<Object[], V>, Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- combineLatest(Function<Object[], V>, int, Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, BiFunction<? super T1, ? super T2, ? extends V>) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- combineLatest(Iterable<? extends Publisher<? extends T>>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- combineLatest(Iterable<? extends Publisher<? extends T>>, int, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux whose data are generated by the combination of the most recent published values from all
 publishers. 
- complete() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- complete() - Method in interface reactor.core.publisher.FluxSink
-  
- complete(Subscriber<?>) - Static method in class reactor.core.publisher.Operators
- 
Calls onSubscribe on the target Subscriber with the empty instance followed by a call to onComplete. 
- complete(O) - Method in class reactor.core.publisher.Operators.MonoSubscriber
- 
Tries to emit the value and complete the underlying subscriber or
 stores the value away until there is a request for it. 
- complete() - Static method in class reactor.core.publisher.Signal
- 
Creates and returns a Signalof varietyType.COMPLETE.
 
- complete() - Method in interface reactor.core.publisher.SynchronousSink
-  
- compose(Function<? super Flux<T>, ? extends Publisher<V>>) - Method in class reactor.core.publisher.Flux
- 
Defer the transformation of this  Flux in order to generate a target  Flux for each
 new  Subscriber. 
- compose(Function<? super Mono<T>, ? extends Publisher<V>>) - Method in class reactor.core.publisher.Mono
- 
Defer the given transformation to this  Mono in order to generate a
 target  Mono type. 
- composeGroup(Function<? super GroupedFlux<Integer, T>, ? extends Publisher<? extends U>>) - Method in class reactor.core.publisher.ParallelFlux
- 
Allows composing operators off the 'rails', as individual  GroupedFlux instances keyed by
 the zero based rail's index. 
- concat(Iterable<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
- 
- concat(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
- 
Concat all sources emitted as an onNext signal from a parent  Publisher. 
- concat(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
- 
Concat all sources emitted as an onNext signal from a parent  Publisher. 
- concat(Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
- 
Concat all sources pulled from the given  Publisher array. 
- concatDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
- 
Concat all sources emitted as an onNext signal from a parent  Publisher. 
- concatDelayError(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
- 
Concat all sources emitted as an onNext signal from a parent  Publisher. 
- concatDelayError(Publisher<? extends Publisher<? extends T>>, boolean, int) - Static method in class reactor.core.publisher.Flux
- 
Concat all sources emitted as an onNext signal from a parent  Publisher. 
- concatDelayError(Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
- 
Concat all sources pulled from the given  Publisher array. 
- concatMap(Function<? super T, ? extends Publisher<? extends V>>) - Method in class reactor.core.publisher.Flux
- 
Bind dynamic sequences given this input sequence like  Flux.flatMap(Function), but preserve
 ordering and concatenate emissions instead of merging (no interleave). 
- concatMap(Function<? super T, ? extends Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
- 
Bind dynamic sequences given this input sequence like  Flux.flatMap(Function), but preserve
 ordering and concatenate emissions instead of merging (no interleave). 
- concatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.ParallelFlux
- 
Generates and concatenates Publishers on each 'rail', signalling errors immediately
 and generating 2 publishers upfront. 
- concatMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class reactor.core.publisher.ParallelFlux
- 
Generates and concatenates Publishers on each 'rail', signalling errors immediately
 and using the given prefetch amount for generating Publishers upfront. 
- concatMapDelayError(Function<? super T, Publisher<? extends V>>) - Method in class reactor.core.publisher.Flux
- 
Bind dynamic sequences given this input sequence like  Flux.flatMap(Function), but preserve
 ordering and concatenate emissions instead of merging (no interleave). 
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
- 
Bind dynamic sequences given this input sequence like  Flux.flatMap(Function), but preserve
 ordering and concatenate emissions instead of merging (no interleave). 
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends V>>, boolean, int) - Method in class reactor.core.publisher.Flux
- 
Bind dynamic sequences given this input sequence like  Flux.flatMap(Function), but preserve
 ordering and concatenate emissions instead of merging (no interleave). 
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.ParallelFlux
- 
Generates and concatenates Publishers on each 'rail',  delaying errors
 and generating 2 publishers upfront. 
- concatMapIterable(Function<? super T, ? extends Iterable<? extends R>>) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into  Iterable, then flatten the elements from those by
 concatening them into a single  Flux. 
- concatMapIterable(Function<? super T, ? extends Iterable<? extends R>>, int) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into  Iterable, then flatten the emissions from those by
 concatening them into a single  Flux. 
- concatWith(Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
Concatenate emissions of this  Flux with the provided  Publisher (no interleave). 
- concatWith(Publisher<? extends T>) - Method in class reactor.core.publisher.Mono
- 
Concatenate emissions of this  Mono with the provided  Publisher
 (no interleave). 
- connect() - Method in class reactor.core.publisher.ConnectableFlux
- 
- connect(Consumer<? super Disposable>) - Method in class reactor.core.publisher.ConnectableFlux
- 
- connect() - Method in class reactor.core.publisher.EmitterProcessor
- 
Deprecated. 
- connect() - Method in class reactor.core.publisher.FluxProcessor
- 
- connect() - Method in class reactor.core.publisher.ReplayProcessor
- 
Deprecated. 
- ConnectableFlux<T> - Class in reactor.core.publisher
- 
The abstract base class for connectable publishers that let subscribers pile up
 before they connect to their data source. 
- ConnectableFlux() - Constructor for class reactor.core.publisher.ConnectableFlux
-  
- connectedInput() - Method in interface reactor.core.Loopback
- 
Deprecated. 
- connectedOutput() - Method in interface reactor.core.Loopback
- 
Deprecated. 
- connectSink() - Method in class reactor.core.publisher.FluxProcessor
- 
- connectSink(boolean) - Method in class reactor.core.publisher.FluxProcessor
- 
- contains(Object) - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- containsAll(Collection<?>) - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- count() - Method in class reactor.core.publisher.Flux
- 
Counts the number of values in this  Flux. 
- create(Subscriber<? super E>, boolean) - Static method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- create(Subscriber<? super E>) - Static method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- create() - Static method in class reactor.core.publisher.DirectProcessor
- 
- create() - Static method in class reactor.core.publisher.EmitterProcessor
- 
- create(boolean) - Static method in class reactor.core.publisher.EmitterProcessor
- 
- create(int) - Static method in class reactor.core.publisher.EmitterProcessor
- 
- create(int, int) - Static method in class reactor.core.publisher.EmitterProcessor
- 
- create(int, boolean) - Static method in class reactor.core.publisher.EmitterProcessor
- 
- create(int, int, boolean) - Static method in class reactor.core.publisher.EmitterProcessor
- 
- create(Consumer<? super FluxSink<T>>) - Static method in class reactor.core.publisher.Flux
- 
Creates a Flux with multi-emission capabilities (synchronous or asynchronous) through
 the FluxSink API. 
- create(Consumer<? super FluxSink<T>>, FluxSink.OverflowStrategy) - Static method in class reactor.core.publisher.Flux
- 
Creates a Flux with multi-emission capabilities (synchronous or asynchronous) through
 the FluxSink API. 
- create(Consumer<MonoSink<T>>) - Static method in class reactor.core.publisher.Mono
- 
Creates a deferred emitter that can be used with callback-based
 APIs to signal at most one value, a complete or an error signal. 
- create() - Static method in class reactor.core.publisher.MonoProcessor
- 
- create(WaitStrategy) - Static method in class reactor.core.publisher.MonoProcessor
- 
- create() - Static method in class reactor.core.publisher.ReplayProcessor
- 
- create(int) - Static method in class reactor.core.publisher.ReplayProcessor
- 
Create a new  ReplayProcessor using a provided backlog size, blockingWait
 Strategy and auto-cancel. 
- create(int, boolean) - Static method in class reactor.core.publisher.ReplayProcessor
- 
Create a new  ReplayProcessor using a provided backlog size, blockingWait
 Strategy and auto-cancel. 
- create() - Static method in class reactor.core.publisher.TopicProcessor
- 
- create(String) - Static method in class reactor.core.publisher.TopicProcessor
- 
- create(boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
- create(ExecutorService) - Static method in class reactor.core.publisher.TopicProcessor
- 
- create(ExecutorService, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
- create(String, int) - Static method in class reactor.core.publisher.TopicProcessor
- 
- create(String, int, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using the blockingWait Strategy, passed backlog
 size, and auto-cancel settings. 
- create(ExecutorService, int) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, blockingWait Strategy
 and will auto-cancel. 
- create(ExecutorService, int, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, blockingWait Strategy
 and the auto-cancel argument. 
- create(String, int, WaitStrategy) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and will
 auto-cancel. 
- create(String, int, WaitStrategy, Supplier<E>) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy, signal
 supplier. 
- create(String, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and
 auto-cancel settings. 
- create(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and will
 auto-cancel. 
- create(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and
 auto-cancel settings. 
- create(ExecutorService, ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and
 auto-cancel settings. 
- create() - Static method in class reactor.core.publisher.UnicastProcessor
- 
Create a unicast  FluxProcessor that will buffer on a given queue in an
 unbounded fashion. 
- create(Queue<T>) - Static method in class reactor.core.publisher.UnicastProcessor
- 
Create a unicast  FluxProcessor that will buffer on a given queue in an
 unbounded fashion. 
- create(Queue<T>, Disposable) - Static method in class reactor.core.publisher.UnicastProcessor
- 
Create a unicast  FluxProcessor that will buffer on a given queue in an
 unbounded fashion. 
- create(Queue<T>, Consumer<? super T>, Disposable) - Static method in class reactor.core.publisher.UnicastProcessor
- 
Create a unicast  FluxProcessor that will buffer on a given queue in an
 unbounded fashion. 
- create() - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
- create(boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
- create(ExecutorService) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
- create(ExecutorService, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
- create(String) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new TopicProcessor using the default buffer size 32, blockingWait
 Strategy and auto-cancel. 
- create(String, int) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new TopicProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel. 
- create(String, int, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new TopicProcessor using the passed buffer size, blockingWait
 Strategy and the passed auto-cancel setting. 
- create(ExecutorService, int) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new TopicProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel. 
- create(ExecutorService, int, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel. 
- create(String, int, WaitStrategy) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel. 
- create(String, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel settings. 
- create(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size and blockingWait
 Strategy settings but will auto-cancel. 
- create(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, wait strategy
 and auto-cancel settings. 
- create(ExecutorService, ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, wait strategy
 and auto-cancel settings. 
- createSizeAndTimeout(int, Duration) - Static method in class reactor.core.publisher.ReplayProcessor
- 
Creates a time- and size-bounded replay processor. 
- createSizeAndTimeout(int, Duration, Scheduler) - Static method in class reactor.core.publisher.ReplayProcessor
- 
Creates a time- and size-bounded replay processor. 
- createSizeAndTimeoutMillis(int, long, TimedScheduler) - Static method in class reactor.core.publisher.ReplayProcessor
- 
- createTimeout(Duration) - Static method in class reactor.core.publisher.ReplayProcessor
- 
Creates a time-bounded replay processor. 
- createTimeout(Duration, Scheduler) - Static method in class reactor.core.publisher.ReplayProcessor
- 
Creates a time-bounded replay processor. 
- createTimeoutMillis(long, TimedScheduler) - Static method in class reactor.core.publisher.ReplayProcessor
- 
- createWorker() - Method in interface reactor.core.scheduler.Scheduler
- 
Creates a worker of this Scheduler that executed task in a strict
 FIFO order, guaranteed non-concurrently with each other. 
- createWorker() - Method in interface reactor.core.scheduler.TimedScheduler
- 
Deprecated. 
- debug(String) - Method in interface reactor.util.Logger
- 
Log a message at the DEBUG level. 
- debug(String, Object...) - Method in interface reactor.util.Logger
- 
Log a message at the DEBUG level according to the specified format
 and arguments. 
- debug(String, Throwable) - Method in interface reactor.util.Logger
- 
Log an exception (throwable) at the DEBUG level with an
 accompanying message. 
- decorateExecutorService(String, Supplier<? extends ExecutorService>) - Static method in class reactor.core.scheduler.Schedulers
-  
- decorateExecutorService(String, Supplier<? extends ExecutorService>) - Method in interface reactor.core.scheduler.Schedulers.Factory
-  
- decorateScheduledExecutorService(String, Supplier<? extends ScheduledExecutorService>) - Static method in class reactor.core.scheduler.Schedulers
-  
- decorateScheduledExecutorService(String, Supplier<? extends ScheduledExecutorService>) - Method in interface reactor.core.scheduler.Schedulers.Factory
-  
- DEFAULT_POOL_SIZE - Static variable in class reactor.core.scheduler.Schedulers
- 
Default number of processors available to the runtime on init (min 4) 
- defaultIfEmpty(T) - Method in class reactor.core.publisher.Flux
- 
Provide a default unique value if this sequence is completed without any data 
- defaultIfEmpty(T) - Method in class reactor.core.publisher.Mono
- 
Provide a default unique value if this mono is completed without any data 
- defer(Supplier<? extends Publisher<T>>) - Static method in class reactor.core.publisher.Flux
- 
Supply a  Publisher everytime subscribe is called on the returned flux. 
- defer(Supplier<? extends Mono<? extends T>>) - Static method in class reactor.core.publisher.Mono
- 
- DeferredSubscription() - Constructor for class reactor.core.publisher.Operators.DeferredSubscription
-  
- delay(Duration) - Method in class reactor.core.publisher.Flux
- 
- delay(Duration) - Static method in class reactor.core.publisher.Mono
- 
Create a Mono which delays an onNext signal of durationof given unit and complete on the global timer.
 
- delay(Duration, Scheduler) - Static method in class reactor.core.publisher.Mono
- 
Create a Mono which delays an onNext signal by a given durationand completes.
 
- delayElement(Duration) - Method in class reactor.core.publisher.Mono
- 
- delayElement(Duration, Scheduler) - Method in class reactor.core.publisher.Mono
- 
- delayElementMillis(long) - Method in class reactor.core.publisher.Mono
- 
- delayElementMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Mono
- 
- delayElements(Duration) - Method in class reactor.core.publisher.Flux
- 
- delayElements(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
- delayElementsMillis(long) - Method in class reactor.core.publisher.Flux
- 
- delayElementsMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- delayMillis(long) - Method in class reactor.core.publisher.Flux
- 
- delayMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- delayMillis(long) - Static method in class reactor.core.publisher.Mono
- 
- delayMillis(long, TimedScheduler) - Static method in class reactor.core.publisher.Mono
- 
- delaySubscription(Duration) - Method in class reactor.core.publisher.Flux
- 
- delaySubscription(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
- delaySubscription(Publisher<U>) - Method in class reactor.core.publisher.Flux
- 
Delay the subscription to the main source until another Publisher
 signals a value or completes. 
- delaySubscription(Duration) - Method in class reactor.core.publisher.Mono
- 
- delaySubscription(Duration, Scheduler) - Method in class reactor.core.publisher.Mono
- 
- delaySubscription(Publisher<U>) - Method in class reactor.core.publisher.Mono
- 
Delay the subscription to this  Mono until another  Publisher
 signals a value or completes. 
- delaySubscriptionMillis(long) - Method in class reactor.core.publisher.Flux
- 
- delaySubscriptionMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- delaySubscriptionMillis(long) - Method in class reactor.core.publisher.Mono
- 
- delaySubscriptionMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Mono
- 
- dematerialize() - Method in class reactor.core.publisher.Flux
- 
A "phantom-operator" working only if this
  Flux is a emits onNext, onError or onComplete  Signal. 
- dematerialize() - Method in class reactor.core.publisher.Mono
- 
A "phantom-operator" working only if this
  Mono is a emits onNext, onError or onComplete  Signal. 
- DirectProcessor<T> - Class in reactor.core.publisher
- 
Dispatches onNext, onError and onComplete signals to zero-to-many Subscribers. 
- Disposable - Interface in reactor.core
- 
Indicates that a task or resource can be cancelled/disposed. 
- dispose() - Method in interface reactor.core.Cancellation
- 
Deprecated. Cancel or dispose the underlying task or resource. 
- dispose() - Method in interface reactor.core.Disposable
- 
Cancel or dispose the underlying task or resource. 
- dispose() - Method in class reactor.core.publisher.BaseSubscriber
- 
- dispose() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- dispose() - Method in class reactor.core.publisher.FluxProcessor
-  
- dispose() - Method in class reactor.core.publisher.MonoProcessor
-  
- dispose() - Method in interface reactor.core.scheduler.Scheduler
- 
Instructs this Scheduler to release all resources and reject
 any new tasks to be executed. 
- dispose() - Method in interface reactor.core.scheduler.Scheduler.Worker
- 
Instructs this worker to cancel all pending tasks, all running tasks in
 a best-effort manner, reject new tasks and
 release any resources associated with it. 
- distinct() - Method in class reactor.core.publisher.Flux
- 
For each  Subscriber, tracks this  Flux values that have been seen and
 filters out duplicates. 
- distinct(Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
- 
For each  Subscriber, tracks this  Flux values that have been seen and
 filters out duplicates given the extracted key. 
- distinctUntilChanged() - Method in class reactor.core.publisher.Flux
- 
Filters out subsequent and repeated elements. 
- distinctUntilChanged(Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
- 
Filters out subsequent and repeated elements provided a matching extracted key. 
- doAfterTerminate(Runnable) - Method in class reactor.core.publisher.Flux
- 
Triggered after the  Flux terminates, either by completing downstream successfully or with an error. 
- doAfterTerminate(BiConsumer<? super T, Throwable>) - Method in class reactor.core.publisher.Mono
- 
Triggered after the  Mono terminates, either by completing downstream successfully or with an error. 
- doAfterTerminate(Runnable) - Method in class reactor.core.publisher.ParallelFlux
- 
Run the specified runnable when a 'rail' completes or signals an error. 
- doCancel() - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- doComplete() - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- doComplete() - Method in class reactor.core.publisher.TopicProcessor
-  
- doComplete() - Method in class reactor.core.publisher.WorkQueueProcessor
-  
- doError(Throwable) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- doError(Throwable) - Method in class reactor.core.publisher.TopicProcessor
-  
- doError(Throwable) - Method in class reactor.core.publisher.WorkQueueProcessor
-  
- doFinally(Consumer<SignalType>) - Method in class reactor.core.publisher.Flux
- 
Triggering  afterthe  Flux terminates for any reason,
 including cancellation. 
- doFinally(Consumer<SignalType>) - Method in class reactor.core.publisher.Mono
- 
Triggering  afterthe  Mono terminates for any reason,
 including cancellation. 
- doNext(I) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- doOnCancel(Runnable) - Method in class reactor.core.publisher.Flux
- 
Triggered when the  Flux is cancelled. 
- doOnCancel(Runnable) - Method in class reactor.core.publisher.Mono
- 
Triggered when the  Mono is cancelled. 
- doOnCancel(Runnable) - Method in class reactor.core.publisher.ParallelFlux
- 
Run the specified runnable when a 'rail' receives a cancellation. 
- doOnComplete(Runnable) - Method in class reactor.core.publisher.Flux
- 
Triggered when the  Flux completes successfully. 
- doOnComplete(Runnable) - Method in class reactor.core.publisher.ParallelFlux
- 
Run the specified runnable when a 'rail' completes. 
- doOnEach(Consumer<? super Signal<T>>) - Method in class reactor.core.publisher.Flux
- 
Triggers side-effects when the  Flux emits an item, fails with an error
 or completes successfully. 
- doOnEach(Consumer<? super T>, Consumer<? super Throwable>, Runnable, Runnable) - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
Peek into sequence signals. 
- doOnEach(Consumer<? super Signal<T>>) - Method in class reactor.core.publisher.Mono
- 
Triggers side-effects when the  Mono emits an item, fails with an error
 or completes successfully. 
- doOnEach(Consumer<? super Signal<T>>) - Method in class reactor.core.publisher.ParallelFlux
- 
Triggers side-effects when the  ParallelFlux emits an item, fails with an error
 or completes successfully. 
- doOnError(Consumer<? super Throwable>) - Method in class reactor.core.publisher.Flux
- 
Triggered when the  Flux completes with an error. 
- doOnError(Class<E>, Consumer<? super E>) - Method in class reactor.core.publisher.Flux
- 
Triggered when the  Flux completes with an error matching the given exception type. 
- doOnError(Predicate<? super Throwable>, Consumer<? super Throwable>) - Method in class reactor.core.publisher.Flux
- 
Triggered when the  Flux completes with an error matching the given exception. 
- doOnError(Consumer<? super Throwable>) - Method in class reactor.core.publisher.Mono
- 
Triggered when the  Mono completes with an error. 
- doOnError(Class<E>, Consumer<? super E>) - Method in class reactor.core.publisher.Mono
- 
Triggered when the  Mono completes with an error matching the given exception type. 
- doOnError(Predicate<? super Throwable>, Consumer<? super Throwable>) - Method in class reactor.core.publisher.Mono
- 
Triggered when the  Mono completes with an error matching the given exception. 
- doOnError(Consumer<? super Throwable>) - Method in class reactor.core.publisher.ParallelFlux
- 
Call the specified consumer with the exception passing through any 'rail'. 
- doOnLifecycle(Consumer<? super Subscription>, LongConsumer, Runnable) - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
Peek into lifecycle signals. 
- doOnNext(Consumer<? super T>) - Method in class reactor.core.publisher.Flux
- 
Triggered when the  Flux emits an item. 
- doOnNext(Consumer<? super T>) - Method in class reactor.core.publisher.Mono
- 
Triggered when the  Mono emits a data successfully. 
- doOnNext(Consumer<? super T>) - Method in class reactor.core.publisher.ParallelFlux
- 
Call the specified consumer with the current element passing through any 'rail'. 
- doOnRequest(LongConsumer) - Method in class reactor.core.publisher.Flux
- 
- doOnRequest(LongConsumer) - Method in class reactor.core.publisher.Mono
- 
- doOnRequest(LongConsumer) - Method in class reactor.core.publisher.ParallelFlux
- 
Call the specified consumer with the request amount if any rail receives a
 request. 
- doOnSubscribe(Consumer<? super Subscription>) - Method in class reactor.core.publisher.Flux
- 
Triggered when the  Flux is subscribed. 
- doOnSubscribe(Consumer<? super Subscription>) - Method in class reactor.core.publisher.Mono
- 
Triggered when the  Mono is subscribed. 
- doOnSubscribe(Subscription) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. Hook for further processing of onSubscribe's Subscription. 
- doOnSubscribe(Consumer<? super Subscription>) - Method in class reactor.core.publisher.ParallelFlux
- 
Call the specified callback when a 'rail' receives a Subscription from its
 upstream. 
- doOnSubscriberError(Throwable) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- doOnSuccess(Consumer<? super T>) - Method in class reactor.core.publisher.Mono
- 
Triggered when the  Mono completes successfully. 
- doOnTerminate(Runnable) - Method in class reactor.core.publisher.Flux
- 
Triggered when the  Flux terminates, either by completing successfully or with an error. 
- doOnTerminate(BiConsumer<? super T, Throwable>) - Method in class reactor.core.publisher.Mono
- 
Triggered when the  Mono terminates, either by completing successfully or with an error. 
- doOnTerminate(Runnable) - Method in class reactor.core.publisher.ParallelFlux
- 
Triggered when the  ParallelFlux terminates, either by completing successfully or with an error. 
- doRequest(long) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- downstream() - Method in interface reactor.core.Producer
- 
Deprecated. Return the direct data receiver. 
- downstream() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- downstream() - Method in class reactor.core.publisher.MonoProcessor
-  
- downstream() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- downstream() - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- downstream() - Method in class reactor.core.publisher.UnicastProcessor
-  
- downstreamCount() - Method in interface reactor.core.MultiProducer
- 
Deprecated. the number of downstream receivers 
- downstreamCount() - Method in class reactor.core.publisher.DirectProcessor
-  
- downstreamCount() - Method in class reactor.core.publisher.EmitterProcessor
-  
- downstreamCount() - Method in class reactor.core.publisher.FluxProcessor
- 
Return the number of active  Subscriber or -1 if untracked. 
- downstreamCount() - Method in class reactor.core.publisher.MonoProcessor
-  
- downstreamCount() - Method in class reactor.core.publisher.ReplayProcessor
-  
- downstreamCount() - Method in class reactor.core.publisher.UnicastProcessor
-  
- downstreams() - Method in interface reactor.core.MultiProducer
- 
Deprecated. the connected data receivers 
- downstreams() - Method in class reactor.core.publisher.FluxProcessor
- 
Deprecated. 
- downstreams() - Method in class reactor.core.publisher.MonoProcessor
-  
- drain() - Method in class reactor.core.publisher.TopicProcessor
-  
- drain() - Method in class reactor.core.publisher.WorkQueueProcessor
-  
- drainSubscriber() - Static method in class reactor.core.publisher.Operators
- 
Return a singleton  Subscriber that does not check for double onSubscribe
 and purely request Long.MAX. 
- duplicateOnSubscribeException() - Static method in class reactor.core.Exceptions
-  
- failWithCancel() - Static method in class reactor.core.Exceptions
- 
An exception that is propagated upward and considered as "fatal" as per Reactive
 Stream limited list of exceptions allowed to bubble. 
- failWithOverflow() - Static method in class reactor.core.Exceptions
- 
Return an  IllegalStateException indicating the receiver is overrun by
 more signals than expected in case of a bounded queue, or more generally that data
 couldn't be emitted due to a lack of request 
- failWithOverflow(String) - Static method in class reactor.core.Exceptions
- 
Return an  IllegalStateException indicating the receiver is overrun by
 more signals than expected in case of a bounded queue or more generally that data
 couldn't be emitted due to a lack of request 
- filter(Predicate<? super T>) - Method in class reactor.core.publisher.Flux
- 
Evaluate each accepted value against the given  Predicate. 
- filter(Predicate<? super T>) - Method in class reactor.core.publisher.Mono
- 
Test the result if any of this  Mono and replay it if predicate returns true. 
- filter(Predicate<? super T>) - Method in class reactor.core.publisher.ParallelFlux
- 
Filters the source values on each 'rail'. 
- filterWhen(Function<? super T, ? extends Publisher<Boolean>>) - Method in class reactor.core.publisher.Flux
- 
Test each value emitted by this  Flux asynchronously using a generated
  Publisher<Boolean> test. 
- filterWhen(Function<? super T, ? extends Publisher<Boolean>>, int) - Method in class reactor.core.publisher.Flux
- 
Test each value emitted by this  Flux asynchronously using a generated
  Publisher<Boolean> test. 
- filterWhen(Function<? super T, ? extends Publisher<Boolean>>) - Method in class reactor.core.publisher.Mono
- 
If this  Mono is valued, test the value asynchronously using a generated
  Publisher<Boolean> test. 
- finish() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- first(Mono<? extends T>...) - Static method in class reactor.core.publisher.Mono
- 
Pick the first result coming from any of the given monos and populate a new Mono. 
- first(Iterable<? extends Mono<? extends T>>) - Static method in class reactor.core.publisher.Mono
- 
Pick the first result coming from any of the given monos and populate a new Mono. 
- firstEmitting(Publisher<? extends I>...) - Static method in class reactor.core.publisher.Flux
- 
Select the fastest source who emitted first onNext or onComplete or onError 
- firstEmitting(Iterable<? extends Publisher<? extends I>>) - Static method in class reactor.core.publisher.Flux
- 
Select the fastest source who won the "ambiguous" race and emitted first onNext or onComplete or onError 
- firstEmittingWith(Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
Emit from the fastest first sequence between this publisher and the given publisher 
- flatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into Publishers, then flatten the emissions from those by
 merging them into a single  Flux, so that they may interleave. 
- flatMap(Function<? super T, ? extends Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into Publishers, then flatten the emissions from those by
 merging them into a single  Flux, so that they may interleave. 
- flatMap(Function<? super T, ? extends Publisher<? extends V>>, int, int) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into Publishers, then flatten the emissions from those by
 merging them into a single  Flux, so that they may interleave. 
- flatMap(Function<? super T, ? extends Publisher<? extends V>>, boolean, int, int) - Method in class reactor.core.publisher.Flux
- 
- flatMap(Function<? super T, ? extends Publisher<? extends R>>, Function<Throwable, ? extends Publisher<? extends R>>, Supplier<? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Flux
- 
Transform the signals emitted by this  Flux into Publishers, then flatten the emissions from those by
 merging them into a single  Flux, so that they may interleave. 
- flatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Mono
- 
- flatMap(Function<? super T, ? extends Publisher<? extends R>>, Function<Throwable, ? extends Publisher<? extends R>>, Supplier<? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Mono
- 
- flatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.ParallelFlux
- 
Generates and flattens Publishers on each 'rail'. 
- flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean) - Method in class reactor.core.publisher.ParallelFlux
- 
Generates and flattens Publishers on each 'rail', optionally delaying errors. 
- flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean, int) - Method in class reactor.core.publisher.ParallelFlux
- 
Generates and flattens Publishers on each 'rail', optionally delaying errors and
 having a total number of simultaneous subscriptions to the inner Publishers. 
- flatMap(Function<? super T, ? extends Publisher<? extends R>>, boolean, int, int) - Method in class reactor.core.publisher.ParallelFlux
- 
Generates and flattens Publishers on each 'rail', optionally delaying errors,
 having a total number of simultaneous subscriptions to the inner Publishers and
 using the given prefetch amount for the inner Publishers. 
- flatMapDelayError(Function<? super T, ? extends Publisher<? extends V>>, int, int) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into Publishers, then flatten the emissions from those by
 merging them into a single  Flux, so that they may interleave. 
- flatMapIterable(Function<? super T, ? extends Iterable<? extends R>>) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into  Iterable, then flatten the elements from those by
 merging them into a single  Flux. 
- flatMapIterable(Function<? super T, ? extends Iterable<? extends R>>, int) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into  Iterable, then flatten the emissions from those by
 merging them into a single  Flux. 
- flatMapIterable(Function<? super T, ? extends Iterable<? extends R>>) - Method in class reactor.core.publisher.Mono
- 
Transform the item emitted by this  Mono into  Iterable, , then forward
 its elements into the returned  Flux. 
- flatMapMany(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Mono
- 
Transform the item emitted by this  Mono into a Publisher, then forward
 its emissions into the returned  Flux. 
- flatMapMany(Function<? super T, ? extends Publisher<? extends R>>, Function<? super Throwable, ? extends Publisher<? extends R>>, Supplier<? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Mono
- 
Transform the signals emitted by this  Mono into a Publisher, then forward
 its emissions into the returned  Flux. 
- flatMapSequential(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into Publishers, then flatten the
 emissions from those by merging them into a single  Flux, in order. 
- flatMapSequential(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into Publishers, then flatten the
 emissions from those by merging them into a single  Flux, in order. 
- flatMapSequential(Function<? super T, ? extends Publisher<? extends R>>, int, int) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into Publishers, then flatten the
 emissions from those by merging them into a single  Flux, in order. 
- flatMapSequential(Function<? super T, ? extends Publisher<? extends R>>, boolean, int, int) - Method in class reactor.core.publisher.Flux
- 
- flatMapSequentialDelayError(Function<? super T, ? extends Publisher<? extends R>>, int, int) - Method in class reactor.core.publisher.Flux
- 
Transform the items emitted by this  Flux into Publishers, then flatten the
 emissions from those by merging them into a single  Flux, in order. 
- flowPublisherToFlux(Flow.Publisher<T>) - Static method in class reactor.adapter.JdkFlowAdapter
- 
Return a  Flux from a java  Flow.Publisher
- Flux<T> - Class in reactor.core.publisher
- 
A Reactive Streams  Publisher with rx operators that emits 0 to N elements, and then completes
 (successfully or with an error). 
- Flux() - Constructor for class reactor.core.publisher.Flux
-  
- flux() - Method in class reactor.core.publisher.Mono
- 
- FluxProcessor<IN,OUT> - Class in reactor.core.publisher
- 
- FluxProcessor() - Constructor for class reactor.core.publisher.FluxProcessor
-  
- FluxSink<T> - Interface in reactor.core.publisher
- 
Wrapper API around a downstream Subscriber for emitting any number of
 next signals followed by zero or one onError/onComplete. 
- FluxSink.OverflowStrategy - Enum in reactor.core.publisher
- 
Enumeration for backpressure handling. 
- FluxSource<I,O> - Class in reactor.core.publisher
- 
A connecting  Flux Publisher (right-to-left from a composition chain perspective) 
- FluxSource(Publisher<? extends I>) - Constructor for class reactor.core.publisher.FluxSource
- 
- fn2() - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple2
- fn3() - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple3
- fn3(Function<Tuple3<T1, T2, T3>, R>) - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple3 to R. 
- fn4() - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple4
- fn4(Function<Tuple4<T1, T2, T3, T4>, R>) - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple4 to R. 
- fn5() - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple5
- fn5(Function<Tuple5<T1, T2, T3, T4, T5>, R>) - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple4 to R. 
- fn6() - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple6
- fn6(Function<Tuple6<T1, T2, T3, T4, T5, T6>, R>) - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple6 to R. 
- fn7() - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple7
- fn7(Function<Tuple7<T1, T2, T3, T4, T5, T6, T7>, R>) - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple7 to R. 
- fn8() - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple8
- fn8(Function<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>, R>) - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuple8
- fnAny() - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuples
- fnAny(Function<Tuple2, R>) - Static method in class reactor.util.function.Tuples
- 
A converting function from Object array to  Tuples to R. 
- from(Publisher<? extends T>) - Static method in class reactor.core.publisher.Flux
- 
- from(Publisher<? extends T>) - Static method in class reactor.core.publisher.Mono
- 
Expose the specified  Publisher with the  Mono API, and ensure it will emit 0 or 1 item. 
- from(Publisher<? extends T>) - Static method in class reactor.core.publisher.ParallelFlux
- 
Take a Publisher and prepare to consume it on multiple 'rails' (number of CPUs) in
 a round-robin fashion. 
- from(Publisher<? extends T>, int) - Static method in class reactor.core.publisher.ParallelFlux
- 
Take a Publisher and prepare to consume it on parallelism number of 'rails' ,
 possibly ordered and round-robin fashion. 
- from(Publisher<? extends T>, int, int, Supplier<Queue<T>>) - Static method in class reactor.core.publisher.ParallelFlux
- 
Take a Publisher and prepare to consume it on parallelism number of 'rails'
 and round-robin fashion and use custom prefetch amount and queue
 for dealing with the source Publisher's values. 
- from(Publisher<T>...) - Static method in class reactor.core.publisher.ParallelFlux
- 
Wraps multiple Publishers into a  ParallelFlux which runs them in parallel and
 unordered. 
- from(Object) - Static method in interface reactor.core.Scannable
- 
- fromArray(T[]) - Static method in class reactor.core.publisher.Flux
- 
Create a  Flux that emits the items contained in the provided  Iterable. 
- fromArray(Object[]) - Static method in class reactor.util.function.Tuples
- 
Create a  Tuple2 with the given array if it is small
 enough to fit inside a  Tuple2 to  Tuple8. 
- fromCallable(Callable<? extends T>) - Static method in class reactor.core.publisher.Mono
- 
Create a  Mono producing the value for the  Mono using the given supplier. 
- fromCompletionStage(CompletionStage<? extends T>) - Static method in class reactor.core.publisher.Mono
- 
- fromDirect(Publisher<? extends I>) - Static method in class reactor.core.publisher.Mono
- 
- fromExecutor(Executor) - Static method in class reactor.core.scheduler.Schedulers
- 
Create a  Scheduler which uses a backing  Executor to schedule
 Runnables for async operators. 
- fromExecutor(Executor, boolean) - Static method in class reactor.core.scheduler.Schedulers
- 
Create a  Scheduler which uses a backing  Executor to schedule
 Runnables for async operators. 
- fromExecutorService(ExecutorService) - Static method in class reactor.core.scheduler.Schedulers
- 
- fromExecutorService(ExecutorService, boolean) - Static method in class reactor.core.scheduler.Schedulers
- 
- fromFuture(CompletableFuture<? extends T>) - Static method in class reactor.core.publisher.Mono
- 
- fromIterable(Iterable<? extends T>) - Static method in class reactor.core.publisher.Flux
- 
Create a  Flux that emits the items contained in the provided  Iterable. 
- fromRunnable(Runnable) - Static method in class reactor.core.publisher.Mono
- 
Create a  Mono only producing a completion signal after using the given
 runnable. 
- fromStream(Stream<? extends T>) - Static method in class reactor.core.publisher.Flux
- 
Create a  Flux that emits the items contained in the provided  Stream. 
- fromSupplier(Supplier<? extends T>) - Static method in class reactor.core.publisher.Mono
- 
Create a  Mono producing the value for the  Mono using the given supplier. 
- Fuseable - Interface in reactor.core
- 
- Fuseable.ConditionalSubscriber<T> - Interface in reactor.core
- 
A subscriber variant that can immediately tell if it consumed
 the value or not, avoiding the usual request(1) for dropped
 values. 
- Fuseable.QueueSubscription<T> - Interface in reactor.core
- 
Contract queue-fusion based optimizations for supporting subscriptions. 
- Fuseable.ScalarCallable<T> - Interface in reactor.core
- 
Marker interface indicating that the target can return a value or null
 immediately and thus a viable target for assembly-time optimizations. 
- Fuseable.SynchronousSubscription<T> - Interface in reactor.core
- 
Base class for synchronous sources which have fixed size and can
 emit its items in a pull fashion, thus avoiding the request-accounting
 overhead in many cases. 
- generate(Consumer<SynchronousSink<T>>) - Static method in class reactor.core.publisher.Flux
- 
Generate signals one-by-one via a consumer callback. 
- generate(Callable<S>, BiFunction<S, SynchronousSink<T>, S>) - Static method in class reactor.core.publisher.Flux
- 
Generate signals one-by-one via a function callback. 
- generate(Callable<S>, BiFunction<S, SynchronousSink<T>, S>, Consumer<? super S>) - Static method in class reactor.core.publisher.Flux
- 
Generate signals one-by-one via a function callback. 
- get() - Method in class reactor.core.publisher.MutableNextSignal
-  
- get() - Method in class reactor.core.publisher.Signal
- 
Retrieves the item associated with this (onNext) signal. 
- get(int) - Static method in class reactor.util.concurrent.QueueSupplier
-  
- get() - Method in class reactor.util.concurrent.QueueSupplier
-  
- get(int) - Method in class reactor.util.function.Tuple2
- 
Get the object at the given index. 
- get(int) - Method in class reactor.util.function.Tuple3
-  
- get(int) - Method in class reactor.util.function.Tuple4
-  
- get(int) - Method in class reactor.util.function.Tuple5
-  
- get(int) - Method in class reactor.util.function.Tuple6
-  
- get(int) - Method in class reactor.util.function.Tuple7
-  
- get(int) - Method in class reactor.util.function.Tuple8
-  
- getAndAddCap(AtomicLongFieldUpdater<T>, T, long) - Static method in class reactor.core.publisher.Operators
- 
Concurrent addition bound to Long.MAX_VALUE. 
- getAsLong() - Method in class reactor.core.publisher.MonoProcessor
- 
Returns the internal state from -1 Cancelled to 5 errored, beyond 3 included is
 fulfilled. 
- getBufferSize() - Method in class reactor.core.publisher.EmitterProcessor
-  
- getBufferSize() - Method in class reactor.core.publisher.FluxProcessor
- 
- getBufferSize() - Method in class reactor.core.publisher.ReplayProcessor
- 
Deprecated. 
- getCapacity() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- getCapacity() - Method in class reactor.core.publisher.FluxProcessor
- 
Deprecated. 
- getCapacity() - Method in interface reactor.core.Trackable
- 
Deprecated. Return defined element capacity 
- getError() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- getError() - Method in class reactor.core.publisher.DirectProcessor
-  
- getError() - Method in class reactor.core.publisher.EmitterProcessor
-  
- getError() - Method in class reactor.core.publisher.FluxProcessor
- 
Current error if any, default to null 
- getError() - Method in class reactor.core.publisher.MonoProcessor
-  
- getError() - Method in class reactor.core.publisher.UnicastProcessor
-  
- getError() - Method in interface reactor.core.Trackable
- 
Deprecated. Current error if any, default to null 
- getLogger(String) - Static method in class reactor.util.Loggers
- 
Try getting an appropriate
  Logger whether SLF4J is not present on the classpath or fallback to  Logger. 
- getLogger(Class<?>) - Static method in class reactor.util.Loggers
- 
Try getting an appropriate
  Logger whether SLF4J is not present on the classpath or fallback to  Logger. 
- getName() - Method in interface reactor.util.Logger
- 
Return the name of this Loggerinstance.
 
- getPending() - Method in class reactor.core.publisher.EmitterProcessor
- 
Return the number of parked elements in the emitter backlog. 
- getPending() - Method in class reactor.core.publisher.MonoProcessor
-  
- getPending() - Method in class reactor.core.publisher.TopicProcessor
-  
- getPending() - Method in class reactor.core.publisher.WorkQueueProcessor
-  
- getPending() - Method in interface reactor.core.Trackable
- 
Deprecated. Return current used space in buffer 
- getPrefetch() - Method in class reactor.core.publisher.DirectProcessor
-  
- getPrefetch() - Method in class reactor.core.publisher.Flux
- 
The prefetch configuration of the  Flux
- getPrefetch() - Method in class reactor.core.publisher.ParallelFlux
- 
The prefetch configuration of the component 
- getPrefetch() - Method in class reactor.core.publisher.ReplayProcessor
-  
- getPrefetch() - Method in class reactor.core.publisher.UnicastProcessor
-  
- getSubscription() - Method in class reactor.core.publisher.MutableNextSignal
-  
- getSubscription() - Method in class reactor.core.publisher.Signal
- 
Read the subscription associated with this (onSubscribe) signal. 
- getT1() - Method in class reactor.util.function.Tuple2
- 
Type-safe way to get the fist object of this  Tuples. 
- getT2() - Method in class reactor.util.function.Tuple2
- 
Type-safe way to get the second object of this  Tuples. 
- getT3() - Method in class reactor.util.function.Tuple3
- 
Type-safe way to get the third object of this  Tuples. 
- getT4() - Method in class reactor.util.function.Tuple4
- 
Type-safe way to get the fourth object of this  Tuples. 
- getT5() - Method in class reactor.util.function.Tuple5
- 
Type-safe way to get the fifth object of this  Tuples. 
- getT6() - Method in class reactor.util.function.Tuple6
- 
Type-safe way to get the sixth object of this  Tuples. 
- getT7() - Method in class reactor.util.function.Tuple7
- 
Type-safe way to get the seventh object of this  Tuples. 
- getT8() - Method in class reactor.util.function.Tuple8
- 
Type-safe way to get the eighth object of this  Tuples. 
- getThrowable() - Method in class reactor.core.publisher.MutableNextSignal
-  
- getThrowable() - Method in class reactor.core.publisher.Signal
- 
Read the error associated with this (onError) signal. 
- getType() - Method in class reactor.core.publisher.MutableNextSignal
-  
- getType() - Method in class reactor.core.publisher.Signal
- 
Read the type of this signal: Subscribe,Next,Error, orComplete
 
- groupBy(Function<? super T, ? extends K>) - Method in class reactor.core.publisher.Flux
- 
Re-route this sequence into dynamically created  Flux for each unique key evaluated by the given
 key mapper. 
- groupBy(Function<? super T, ? extends K>, int) - Method in class reactor.core.publisher.Flux
- 
Re-route this sequence into dynamically created  Flux for each unique key evaluated by the given
 key mapper. 
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
- 
Re-route this sequence into dynamically created  Flux for each unique key evaluated by the given
 key mapper. 
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, int) - Method in class reactor.core.publisher.Flux
- 
Re-route this sequence into dynamically created  Flux for each unique key evaluated by the given
 key mapper. 
- GroupedFlux<K,V> - Class in reactor.core.publisher
- 
Represents a sequence of events with an associated key. 
- GroupedFlux() - Constructor for class reactor.core.publisher.GroupedFlux
-  
- groupJoin(Publisher<? extends TRight>, Function<? super T, ? extends Publisher<TLeftEnd>>, Function<? super TRight, ? extends Publisher<TRightEnd>>, BiFunction<? super T, ? super Flux<TRight>, ? extends R>) - Method in class reactor.core.publisher.Flux
- 
Returns a  Flux that correlates two Publishers when they overlap in time
 and groups the results. 
- groups() - Method in class reactor.core.publisher.ParallelFlux
- 
Exposes the 'rails' as individual GroupedFlux instances, keyed by the rail
 index (zero based). 
- ifFlux() - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
- ifMono() - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
- ifName(String...) - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
Apply hook only if  Hooks.OperatorHook.publisher() if operator name match the type name
 (case insensitive, without Mono/Flux prefix or Fuseable suffix. 
- ifNameContains(String...) - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
Apply hook only if  Hooks.OperatorHook.publisher() if operator name match the type name
 (case insensitive, without Mono/Flux prefix or Fuseable suffix. 
- ifParallelFlux() - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
- ignore() - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
- ignoreElement() - Method in class reactor.core.publisher.Mono
- 
Ignores onNext signal (dropping it) and only reacts on termination. 
- ignoreElements() - Method in class reactor.core.publisher.Flux
- 
Ignores onNext signals (dropping them) and only reacts on termination. 
- ignoreElements(Publisher<T>) - Static method in class reactor.core.publisher.Mono
- 
Create a new  Mono that ignores onNext (dropping them) and only react on Completion signal. 
- immediate() - Static method in class reactor.core.scheduler.Schedulers
- 
Executes tasks on the caller's thread immediately. 
- info(String) - Method in interface reactor.util.Logger
- 
Log a message at the INFO level. 
- info(String, Object...) - Method in interface reactor.util.Logger
- 
Log a message at the INFO level according to the specified format
 and arguments. 
- info(String, Throwable) - Method in interface reactor.util.Logger
- 
Log an exception (throwable) at the INFO level with an
 accompanying message. 
- inners() - Method in class reactor.core.publisher.DirectProcessor
-  
- inners() - Method in class reactor.core.publisher.EmitterProcessor
-  
- inners() - Method in class reactor.core.publisher.FluxProcessor
-  
- inners() - Method in class reactor.core.publisher.ReplayProcessor
-  
- inners() - Method in interface reactor.core.Scannable
- 
Return a  Stream of referenced inners (flatmap, multicast etc) 
- innerToString() - Method in class reactor.util.function.Tuple2
-  
- innerToString() - Method in class reactor.util.function.Tuple3
-  
- innerToString() - Method in class reactor.util.function.Tuple4
-  
- innerToString() - Method in class reactor.util.function.Tuple5
-  
- innerToString() - Method in class reactor.util.function.Tuple6
-  
- innerToString() - Method in class reactor.util.function.Tuple7
-  
- innerToString() - Method in class reactor.util.function.Tuple8
-  
- interval(Duration) - Static method in class reactor.core.publisher.Flux
- 
Create a  Flux that emits an ever incrementing long starting with 0 every period on
 the global timer. 
- interval(Duration, Duration) - Static method in class reactor.core.publisher.Flux
- 
Create a  Flux that emits an ever incrementing long starting with 0 every N period of time unit on
 a global timer. 
- interval(Duration, Scheduler) - Static method in class reactor.core.publisher.Flux
- 
Create a  Flux that emits an ever incrementing long starting with 0 every  Duration on
 the given timer. 
- interval(Duration, Duration, Scheduler) - Static method in class reactor.core.publisher.Flux
- 
Create a  Flux that emits an ever incrementing long starting with 0 every N period of time on
 the given timer. 
- intervalMillis(long) - Static method in class reactor.core.publisher.Flux
- 
- intervalMillis(long, TimedScheduler) - Static method in class reactor.core.publisher.Flux
- 
- intervalMillis(long, long) - Static method in class reactor.core.publisher.Flux
- 
- intervalMillis(long, long, TimedScheduler) - Static method in class reactor.core.publisher.Flux
- 
- isAlert(Throwable) - Static method in class reactor.util.concurrent.WaitStrategy
- 
Test if exception is alert 
- isBackpressured() - Method in enum reactor.core.publisher.BlockingSink.Emission
- 
Deprecated. 
- isBubbling(Throwable) - Static method in class reactor.core.Exceptions
- 
Check if the given error is a bubbled wrapped exception. 
- isCancel(Throwable) - Static method in class reactor.core.Exceptions
- 
Check if the given error is a cancel signal. 
- isCancelled() - Method in enum reactor.core.publisher.BlockingSink.Emission
- 
Deprecated. 
- isCancelled() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- isCancelled() - Method in class reactor.core.publisher.EmitterProcessor
- 
- isCancelled() - Method in interface reactor.core.publisher.FluxSink
- 
Returns true if the downstream cancelled the sequence. 
- isCancelled() - Method in class reactor.core.publisher.MonoProcessor
-  
- isCancelled() - Method in class reactor.core.publisher.Operators.DeferredSubscription
-  
- isCancelled() - Method in class reactor.core.publisher.Operators.MonoSubscriber
- 
Returns true if this Subscription has been cancelled. 
- isCancelled() - Method in interface reactor.core.Trackable
- 
Deprecated. 
- isComplete(Object) - Static method in class reactor.core.publisher.Signal
-  
- isDebugEnabled() - Method in interface reactor.util.Logger
- 
Is the logger instance enabled for the DEBUG level? 
- isDisposed() - Method in interface reactor.core.Disposable
- 
Optionally return true when the resource or task is disposed. 
- isDisposed() - Method in class reactor.core.publisher.BaseSubscriber
-  
- isDisposed() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- isDisposed() - Method in class reactor.core.publisher.MonoProcessor
-  
- isDisposed() - Method in class reactor.core.publisher.UnicastProcessor
-  
- isEmpty() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- isEmpty() - Method in class reactor.core.publisher.UnicastProcessor
-  
- isEmpty() - Method in class reactor.util.concurrent.OpenHashSet
-  
- isError() - Method in class reactor.core.publisher.MonoProcessor
- 
Indicates whether this MonoProcessorhas been completed with an error.
 
- isError(Object) - Static method in class reactor.core.publisher.Signal
-  
- isErrorCallbackNotImplemented(Throwable) - Static method in class reactor.core.Exceptions
- 
- isErrorEnabled() - Method in interface reactor.util.Logger
- 
Is the logger instance enabled for the ERROR level? 
- isFailed() - Method in enum reactor.core.publisher.BlockingSink.Emission
- 
Deprecated. 
- isInfoEnabled() - Method in interface reactor.util.Logger
- 
Is the logger instance enabled for the INFO level? 
- isOk() - Method in enum reactor.core.publisher.BlockingSink.Emission
- 
Deprecated. 
- isOnComplete() - Method in class reactor.core.publisher.Signal
- 
Indicates whether this signal represents an onCompleteevent.
 
- isOnError() - Method in class reactor.core.publisher.Signal
- 
Indicates whether this signal represents an onErrorevent.
 
- isOnNext() - Method in class reactor.core.publisher.Signal
- 
Indicates whether this signal represents an onNextevent.
 
- isOnSubscribe() - Method in class reactor.core.publisher.Signal
- 
Indicates whether this signal represents an onSubscribeevent.
 
- isOrdered() - Method in class reactor.core.publisher.ParallelFlux
- 
- isOverflow(Throwable) - Static method in class reactor.core.Exceptions
-  
- isPowerOfTwo(int) - Static method in class reactor.util.concurrent.QueueSupplier
-  
- isScanAvailable() - Method in interface reactor.core.Scannable
- 
- isSerialized() - Method in class reactor.core.publisher.FluxProcessor
- 
- isStarted() - Method in class reactor.core.publisher.BaseSubscriber
-  
- isStarted() - Method in class reactor.core.publisher.EmitterProcessor
- 
Deprecated. 
- isStarted() - Method in class reactor.core.publisher.FluxProcessor
- 
- isStarted() - Method in class reactor.core.publisher.MonoProcessor
-  
- isStarted() - Method in class reactor.core.publisher.ReplayProcessor
- 
Deprecated. 
- isStarted() - Method in class reactor.core.publisher.UnicastProcessor
- 
Deprecated. 
- isStarted() - Method in interface reactor.core.Trackable
- 
Deprecated. Has this upstream started or "onSubscribed" ? 
- isSuccess() - Method in class reactor.core.publisher.MonoProcessor
- 
Indicates whether this MonoProcessorhas been successfully completed a value.
 
- isTerminated() - Method in class reactor.core.publisher.BaseSubscriber
- 
- isTerminated() - Method in class reactor.core.publisher.DirectProcessor
-  
- isTerminated() - Method in class reactor.core.publisher.EmitterProcessor
-  
- isTerminated() - Method in class reactor.core.publisher.FluxProcessor
- 
Has this upstream finished or "completed" / "failed" ? 
- isTerminated() - Method in class reactor.core.publisher.MonoProcessor
-  
- isTerminated() - Method in class reactor.core.publisher.ReplayProcessor
-  
- isTerminated() - Method in class reactor.core.publisher.UnicastProcessor
-  
- isTerminated() - Method in interface reactor.core.Trackable
- 
Deprecated. Has this upstream finished or "completed" / "failed" ? 
- isTraceEnabled() - Method in interface reactor.util.Logger
- 
Is the logger instance enabled for the TRACE level? 
- isWarnEnabled() - Method in interface reactor.util.Logger
- 
Is the logger instance enabled for the WARN level? 
- iterator() - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- iterator() - Method in class reactor.util.function.Tuple2
-  
- of(T) - Static method in class reactor.core.publisher.MutableNextSignal
- 
- of(T1, T2) - Static method in class reactor.util.function.Tuples
- 
Create a  Tuple2 with the given objects. 
- of(T1, T2, T3) - Static method in class reactor.util.function.Tuples
- 
Create a  Tuple3 with the given objects. 
- of(T1, T2, T3, T4) - Static method in class reactor.util.function.Tuples
- 
Create a  Tuple4 with the given objects. 
- of(T1, T2, T3, T4, T5) - Static method in class reactor.util.function.Tuples
- 
Create a  Tuple5 with the given objects. 
- of(T1, T2, T3, T4, T5, T6) - Static method in class reactor.util.function.Tuples
- 
Create a  Tuple6 with the given objects. 
- of(T1, T2, T3, T4, T5, T6, T7) - Static method in class reactor.util.function.Tuples
- 
Create a  Tuple7 with the given objects. 
- of(T1, T2, T3, T4, T5, T6, T7, T8) - Static method in class reactor.util.function.Tuples
- 
Create a  Tuple8 with the given objects. 
- offer(T) - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- ofType(Class<U>) - Method in class reactor.core.publisher.Flux
- 
Evaluate each accepted value against the given  Class type. 
- ofType(Class<U>) - Method in class reactor.core.publisher.Mono
- 
Evaluate the accepted value against the given  Class type. 
- onAssembly(Flux<T>) - Static method in class reactor.core.publisher.Flux
- 
Invoke  Hooks pointcut given a  Flux and returning an eventually
 new  Flux
- onAssembly(ConnectableFlux<T>) - Static method in class reactor.core.publisher.Flux
- 
- onAssembly(Mono<T>) - Static method in class reactor.core.publisher.Mono
- 
Invoke  Hooks pointcut given a  Mono and returning an eventually
 new  Mono
- onAssembly(ParallelFlux<T>) - Static method in class reactor.core.publisher.ParallelFlux
- 
- onBackpressureBuffer() - Method in class reactor.core.publisher.Flux
- 
Request an unbounded demand and push the returned  Flux, or park the observed elements if not enough
 demand is requested downstream. 
- onBackpressureBuffer(int) - Method in class reactor.core.publisher.Flux
- 
Request an unbounded demand and push the returned  Flux, or park the observed elements if not enough
 demand is requested downstream. 
- onBackpressureBuffer(int, Consumer<? super T>) - Method in class reactor.core.publisher.Flux
- 
Request an unbounded demand and push the returned  Flux, or park the observed elements if not enough
 demand is requested downstream. 
- onBackpressureBuffer(int, BufferOverflowStrategy) - Method in class reactor.core.publisher.Flux
- 
Request an unbounded demand and push the returned  Flux, or park the observed
 elements if not enough demand is requested downstream, within a  maxSize
 limit. 
- onBackpressureBuffer(int, Consumer<? super T>, BufferOverflowStrategy) - Method in class reactor.core.publisher.Flux
- 
Request an unbounded demand and push the returned  Flux, or park the observed
 elements if not enough demand is requested downstream, within a  maxSize
 limit. 
- onBackpressureDrop() - Method in class reactor.core.publisher.Flux
- 
Request an unbounded demand and push the returned  Flux, or drop the observed elements if not enough
 demand is requested downstream. 
- onBackpressureDrop(Consumer<? super T>) - Method in class reactor.core.publisher.Flux
- 
Request an unbounded demand and push the returned  Flux, or drop and notify dropping  Consumer
 with the observed elements if not enough demand is requested downstream. 
- onBackpressureError() - Method in class reactor.core.publisher.Flux
- 
- onBackpressureLatest() - Method in class reactor.core.publisher.Flux
- 
Request an unbounded demand and push the returned  Flux, or only keep the most recent observed item
 if not enough demand is requested downstream. 
- onCancel(Disposable) - Method in interface reactor.core.publisher.FluxSink
- 
Associates a disposable resource with this FluxSink
 that will be disposed in case the downstream cancels the sequence
 via  Subscription.cancel(). 
- onCancel(Disposable) - Method in interface reactor.core.publisher.MonoSink
- 
Associates a disposable resource with this MonoSink that will be disposed on
 downstream.cancel(). 
- onComplete() - Method in class reactor.core.publisher.BaseSubscriber
-  
- onComplete() - Method in class reactor.core.publisher.DirectProcessor
-  
- onComplete() - Method in class reactor.core.publisher.EmitterProcessor
-  
- onComplete() - Method in class reactor.core.publisher.MonoProcessor
-  
- onComplete() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- onComplete() - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- onComplete() - Method in class reactor.core.publisher.ReplayProcessor
-  
- onComplete() - Method in class reactor.core.publisher.UnicastProcessor
-  
- onDispose(Disposable) - Method in interface reactor.core.publisher.FluxSink
- 
Associates a disposable resource with this FluxSink
 that will be disposed on the first terminate signal which may be
 a cancel, complete or error signal. 
- onDispose(Disposable) - Method in interface reactor.core.publisher.MonoSink
- 
Associates a disposable resource with this MonoSink that will be disposed on the
 first terminate signal which may be a cancel, complete or error signal. 
- one() - Static method in class reactor.util.concurrent.QueueSupplier
-  
- onError(Throwable) - Method in class reactor.core.publisher.BaseSubscriber
-  
- onError(Throwable) - Method in class reactor.core.publisher.DirectProcessor
-  
- onError(Throwable) - Method in class reactor.core.publisher.EmitterProcessor
-  
- onError(Throwable) - Method in class reactor.core.publisher.MonoProcessor
-  
- onError(Throwable) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- onError(Throwable) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- onError(Throwable) - Method in class reactor.core.publisher.ReplayProcessor
-  
- onError(Throwable) - Method in class reactor.core.publisher.UnicastProcessor
-  
- onErrorDropped(Consumer<? super Throwable>) - Static method in class reactor.core.publisher.Hooks
- 
Override global error dropped strategy which by default bubble back the error. 
- onErrorDropped(Throwable, Throwable) - Static method in class reactor.core.publisher.Operators
- 
Take an unsignalled exception that is masking anowher one due to callback failure. 
- onErrorDropped(Throwable) - Static method in class reactor.core.publisher.Operators
- 
Take an unsignalled exception that is masking another one due to callback failure. 
- onErrorMap(Function<? super Throwable, ? extends Throwable>) - Method in class reactor.core.publisher.Flux
- 
Transform the error emitted by this  Flux by applying a function. 
- onErrorMap(Class<E>, Function<? super E, ? extends Throwable>) - Method in class reactor.core.publisher.Flux
- 
Transform the error emitted by this  Flux by applying a function if the
 error matches the given type, otherwise let the error flow. 
- onErrorMap(Predicate<? super Throwable>, Function<? super Throwable, ? extends Throwable>) - Method in class reactor.core.publisher.Flux
- 
Transform the error emitted by this  Flux by applying a function if the
 error matches the given predicate, otherwise let the error flow. 
- onErrorMap(Function<? super Throwable, ? extends Throwable>) - Method in class reactor.core.publisher.Mono
- 
Transform the error emitted by this  Mono by applying a function. 
- onErrorMap(Class<E>, Function<? super E, ? extends Throwable>) - Method in class reactor.core.publisher.Mono
- 
Transform the error emitted by this  Mono by applying a function if the
 error matches the given type, otherwise let the error flow. 
- onErrorMap(Predicate<? super Throwable>, Function<? super Throwable, ? extends Throwable>) - Method in class reactor.core.publisher.Mono
- 
Transform the error emitted by this  Mono by applying a function if the
 error matches the given predicate, otherwise let the error flow. 
- onErrorResume(Function<? super Throwable, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
- 
Subscribe to a returned fallback publisher when any error occurs. 
- onErrorResume(Class<E>, Function<? super E, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
- 
Subscribe to a returned fallback publisher when an error matching the given type
 occurs. 
- onErrorResume(Predicate<? super Throwable>, Function<? super Throwable, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
- 
Subscribe to a returned fallback publisher when an error matching the given type
 occurs. 
- onErrorResume(Function<? super Throwable, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
- 
Subscribe to a returned fallback publisher when any error occurs. 
- onErrorResume(Class<E>, Function<? super E, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
- 
Subscribe to a returned fallback publisher when an error matching the given type
 occurs. 
- onErrorResume(Predicate<? super Throwable>, Function<? super Throwable, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
- 
$        * Subscribe to a returned fallback publisher when an error matching the given predicate
 occurs. 
- onErrorResumeWith(Function<? super Throwable, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
- 
- onErrorResumeWith(Class<E>, Function<? super E, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
- 
- onErrorResumeWith(Predicate<? super Throwable>, Function<? super Throwable, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
- 
- onErrorReturn(T) - Method in class reactor.core.publisher.Flux
- 
Fallback to the given value if an error is observed on this  Flux
- onErrorReturn(Class<E>, T) - Method in class reactor.core.publisher.Flux
- 
Fallback to the given value if an error of a given type is observed on this
  Flux
- onErrorReturn(Predicate<? super Throwable>, T) - Method in class reactor.core.publisher.Flux
- 
Fallback to the given value if an error matching the given predicate is
 observed on this
  Flux
- onErrorReturn(T) - Method in class reactor.core.publisher.Mono
- 
Simply emit a captured fallback value when any error is observed on this  Mono. 
- onErrorReturn(Class<E>, T) - Method in class reactor.core.publisher.Mono
- 
Simply emit a captured fallback value when an error of the specified type is
 observed on this  Mono. 
- onErrorReturn(Predicate<? super Throwable>, T) - Method in class reactor.core.publisher.Mono
- 
Simply emit a captured fallback value when an error matching the given predicate is
 observed on this  Mono. 
- onHandleError(BiConsumer<Thread, ? super Throwable>) - Static method in class reactor.core.scheduler.Schedulers
- 
- onNext(T) - Method in class reactor.core.publisher.BaseSubscriber
-  
- onNext(T) - Method in class reactor.core.publisher.DirectProcessor
-  
- onNext(T) - Method in class reactor.core.publisher.EmitterProcessor
-  
- onNext(O) - Method in class reactor.core.publisher.MonoProcessor
-  
- onNext(I) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- onNext(I) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- onNext(T) - Method in class reactor.core.publisher.ReplayProcessor
-  
- onNext(T) - Method in class reactor.core.publisher.UnicastProcessor
-  
- onNextDropped(Consumer<Object>) - Static method in class reactor.core.publisher.Hooks
- 
- onNextDropped(T) - Static method in class reactor.core.publisher.Operators
- 
An unexpected event is about to be dropped. 
- onOperator(Function<? super Hooks.OperatorHook<T>, ? extends Hooks.OperatorHook<T>>) - Static method in class reactor.core.publisher.Hooks
- 
Set a global "assembly" hook to intercept signals produced by the passed  Publisher ( Flux or  Mono). 
- onOperatorError(BiFunction<? super Throwable, Object, ? extends Throwable>) - Static method in class reactor.core.publisher.Hooks
- 
Override global operator error mapping which by default add as suppressed exception
 either data driven exception or error driven exception. 
- onOperatorError(Throwable) - Static method in class reactor.core.publisher.Operators
- 
Map an "operator" error. 
- onOperatorError(Subscription, Throwable) - Static method in class reactor.core.publisher.Operators
- 
Map an "operator" error given an operator parent  Subscription. 
- onOperatorError(Subscription, Throwable, Object) - Static method in class reactor.core.publisher.Operators
- 
Map an "operator" error given an operator parent  Subscription. 
- onRejectedExecution() - Static method in class reactor.core.publisher.Operators
- 
- onRejectedExecution(Subscription, Throwable, Object) - Static method in class reactor.core.publisher.Operators
- 
- onRequest(LongConsumer) - Method in interface reactor.core.publisher.FluxSink
- 
- onRequest(LongConsumer) - Method in interface reactor.core.publisher.MonoSink
- 
- onSubscribe(Subscription) - Method in class reactor.core.publisher.BaseSubscriber
-  
- onSubscribe(Subscription) - Method in class reactor.core.publisher.DirectProcessor
-  
- onSubscribe(Subscription) - Method in class reactor.core.publisher.EmitterProcessor
-  
- onSubscribe(Subscription) - Method in class reactor.core.publisher.MonoProcessor
-  
- onSubscribe(Subscription) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- onSubscribe(Subscription) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- onSubscribe(Subscription) - Method in class reactor.core.publisher.ReplayProcessor
-  
- onSubscribe(Subscription) - Method in class reactor.core.publisher.UnicastProcessor
-  
- onTerminateDetach() - Method in class reactor.core.publisher.Flux
- 
- onTerminateDetach() - Method in class reactor.core.publisher.Mono
- 
- OpenHashSet<T> - Class in reactor.util.concurrent
- 
A simple open hash set with add, remove and clear capabilities only. 
- OpenHashSet() - Constructor for class reactor.util.concurrent.OpenHashSet
-  
- OpenHashSet(int, float) - Constructor for class reactor.util.concurrent.OpenHashSet
-  
- Operators - Class in reactor.core.publisher
- 
An helper to support "Operator" writing, handle noop subscriptions, validate request
 size and
 to cap concurrent additive operations to Long.MAX_VALUE,
 which is generic to  Subscription.request(long) handling. 
- Operators.DeferredSubscription - Class in reactor.core.publisher
- 
Base class for Subscribers that will receive their Subscriptions at any time yet
 they need to be cancelled or requested at any time. 
- Operators.MonoSubscriber<I,O> - Class in reactor.core.publisher
- 
A Subscriber/Subscription barrier that holds a single value at most and properly gates asynchronous behaviors
 resulting from concurrent request or cancel and onXXX signals. 
- Operators.SubscriberAdapter<I,O> - Class in reactor.core.publisher
- 
- operatorStacktrace() - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
Enable operator stack recorder and capture declaration stack. 
- or(Mono<? extends T>) - Method in class reactor.core.publisher.Mono
- 
Emit the any of the result from this mono or from the given mono 
- otherwise(Function<? super Throwable, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
- 
- otherwise(Class<E>, Function<? super E, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
- 
- otherwise(Predicate<? super Throwable>, Function<? super Throwable, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
- 
- otherwiseIfEmpty(Mono<? extends T>) - Method in class reactor.core.publisher.Mono
- 
- otherwiseReturn(T) - Method in class reactor.core.publisher.Mono
- 
- otherwiseReturn(Class<E>, T) - Method in class reactor.core.publisher.Mono
- 
- otherwiseReturn(Predicate<? super Throwable>, T) - Method in class reactor.core.publisher.Mono
- 
- parallel() - Method in class reactor.core.publisher.Flux
- 
Prepare to consume this  Flux on number of 'rails' matching number of CPU
 in round-robin fashion. 
- parallel(int) - Method in class reactor.core.publisher.Flux
- 
Prepare to consume this  Flux on parallelism number of 'rails'
 in round-robin fashion. 
- parallel(int, int) - Method in class reactor.core.publisher.Flux
- 
Prepare to consume this  Flux on parallelism number of 'rails'
 in round-robin fashion and use custom prefetch amount and queue
 for dealing with the source  Flux's values. 
- parallel() - Static method in class reactor.core.scheduler.Schedulers
- 
Scheduler that hosts a fixed pool of single-threaded ExecutorService-based
 workers and is suited for parallel work. 
- ParallelFlux<T> - Class in reactor.core.publisher
- 
A ParallelFlux publishes to an array of Subscribers, in parallel 'rails' (or
  'groups'). 
- ParallelFlux() - Constructor for class reactor.core.publisher.ParallelFlux
-  
- parallelism() - Method in class reactor.core.publisher.ParallelFlux
- 
Returns the number of expected parallel Subscribers. 
- parents() - Method in interface reactor.core.Scannable
- 
- parking() - Static method in class reactor.util.concurrent.WaitStrategy
- 
Parking strategy that initially spins, then uses a Thread.yield(), and eventually sleep
 (LockSupport.parkNanos(1)) for the minimum number of nanos the OS and JVM will allow while the
 consumers are waiting on a barrier.
 
- parking(int) - Static method in class reactor.util.concurrent.WaitStrategy
- 
Parking strategy that initially spins, then uses a Thread.yield(), and eventually
 sleep (LockSupport.parkNanos(1)) for the minimum number of nanos the
 OS and JVM will allow while the consumers are waiting on a barrier.
 
- peek() - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- peek() - Method in class reactor.core.publisher.MonoProcessor
- 
- phasedOff(long, long, TimeUnit, WaitStrategy) - Static method in class reactor.util.concurrent.WaitStrategy
- 
Phased wait strategy for waiting consumers on a barrier. 
- phasedOffLiteLock(long, long, TimeUnit) - Static method in class reactor.util.concurrent.WaitStrategy
- 
Block with wait/notifyAll semantics 
- phasedOffLock(long, long, TimeUnit) - Static method in class reactor.util.concurrent.WaitStrategy
- 
Block with wait/notifyAll semantics 
- phasedOffSleep(long, long, TimeUnit) - Static method in class reactor.util.concurrent.WaitStrategy
- 
Block by parking in a loop 
- poll() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- poll() - Method in class reactor.core.publisher.UnicastProcessor
-  
- produced(AtomicLongFieldUpdater<T>, T, long) - Static method in class reactor.core.publisher.Operators
- 
Concurrent substraction bound to 0. 
- Producer - Interface in reactor.core
- 
- propagate(Throwable) - Static method in class reactor.core.Exceptions
- 
- publish() - Method in class reactor.core.publisher.Flux
- 
Prepare a  ConnectableFlux which shares this  Flux sequence and dispatches values to
 subscribers in a backpressure-aware manner. 
- publish(int) - Method in class reactor.core.publisher.Flux
- 
Prepare a  ConnectableFlux which shares this  Flux sequence and dispatches values to
 subscribers in a backpressure-aware manner. 
- publish(Function<? super Flux<T>, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Flux
- 
Shares a sequence for the duration of a function that may transform it and
 consume it as many times as necessary without causing multiple subscriptions
 to the upstream. 
- publish(Function<? super Flux<T>, ? extends Publisher<? extends R>>, int) - Method in class reactor.core.publisher.Flux
- 
Shares a sequence for the duration of a function that may transform it and
 consume it as many times as necessary without causing multiple subscriptions
 to the upstream. 
- publish(Function<? super Mono<T>, ? extends Mono<? extends R>>) - Method in class reactor.core.publisher.Mono
- 
Shares a  Mono for the duration of a function that may transform it and
 consume it as many times as necessary without causing multiple subscriptions
 to the upstream. 
- publisher() - Method in class reactor.core.publisher.Hooks.OperatorHook
- 
The current publisher to decorate 
- publisherToFlowPublisher(Publisher<T>) - Static method in class reactor.adapter.JdkFlowAdapter
- 
Return a  Flux from a java  Flow.Publisher
- publishNext() - Method in class reactor.core.publisher.Flux
- 
Prepare a  Mono which shares this  Flux sequence and dispatches the first observed item to
 subscribers in a backpressure-aware manner. 
- publishOn(Scheduler) - Method in class reactor.core.publisher.Flux
- 
- publishOn(Scheduler, int) - Method in class reactor.core.publisher.Flux
- 
- publishOn(Scheduler, boolean, int) - Method in class reactor.core.publisher.Flux
- 
- publishOn(Scheduler) - Method in class reactor.core.publisher.Mono
- 
Run onNext, onComplete and onError on a supplied  Scheduler
- push(Consumer<? super FluxSink<T>>) - Static method in class reactor.core.publisher.Flux
- 
Creates a Flux with multi-emission capabilities from a single threaded producer
 through the FluxSink API. 
- push(Consumer<? super FluxSink<T>>, FluxSink.OverflowStrategy) - Static method in class reactor.core.publisher.Flux
- 
Creates a Flux with multi-emission capabilities from a single threaded producer
 through the FluxSink API. 
- range(int, int) - Static method in class reactor.core.publisher.Flux
- 
Build a  Flux that will only emit a sequence of incrementing integer from  start to  start + count then complete. 
- reactor.adapter - package reactor.adapter
- 
- reactor.core - package reactor.core
- 
Core components of the framework supporting extensions to the Reactive Stream
 programming model. 
- reactor.core.publisher - package reactor.core.publisher
- 
- reactor.core.scheduler - package reactor.core.scheduler
- 
- reactor.util - package reactor.util
- 
Miscellaneous utility classes, such as loggers, tuples or queue suppliers and implementations. 
- reactor.util.concurrent - package reactor.util.concurrent
- 
- reactor.util.function - package reactor.util.function
- 
Tuples provide a type-safe way to specify multiple parameters. 
- Receiver - Interface in reactor.core
- 
- reduce(BiFunction<T, T, T>) - Method in class reactor.core.publisher.Flux
- 
Aggregate the values from this  Flux sequence into an object of the same type than the
 emitted items. 
- reduce(A, BiFunction<A, ? super T, A>) - Method in class reactor.core.publisher.Flux
- 
Accumulate the values from this  Flux sequence into an object matching an initial value type. 
- reduce(BiFunction<T, T, T>) - Method in class reactor.core.publisher.ParallelFlux
- 
Reduces all values within a 'rail' and across 'rails' with a reducer function into
 a single sequential value. 
- reduce(Supplier<R>, BiFunction<R, ? super T, R>) - Method in class reactor.core.publisher.ParallelFlux
- 
Reduces all values within a 'rail' to a single value (with a possibly different
 type) via a reducer function that is initialized on each rail from an
 initialSupplier value. 
- reduceWith(Supplier<A>, BiFunction<A, ? super T, A>) - Method in class reactor.core.publisher.Flux
- 
Accumulate the values from this  Flux sequence into an object matching an initial value type. 
- refCount() - Method in class reactor.core.publisher.ConnectableFlux
- 
Connects to the upstream source when the first  Subscriber subscribes and disconnects
 when all Subscribers cancelled or the upstream source completed. 
- refCount(int) - Method in class reactor.core.publisher.ConnectableFlux
- 
Connects to the upstream source when the given number of  Subscriber subscribes and disconnects
 when all Subscribers cancelled or the upstream source completed. 
- REJECTED - Static variable in interface reactor.core.scheduler.Scheduler
- 
Returned by the schedule() methods if the Scheduler or the Worker has ben shut down,
 or is incapable of scheduling tasks with a delay/periodically (not "time capable"). 
- remove() - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- remove(Object) - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- remove(T) - Method in class reactor.util.concurrent.OpenHashSet
-  
- removeAll(Collection<?>) - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- repeat() - Method in class reactor.core.publisher.Flux
- 
Repeatedly subscribe to the source completion of the previous subscription. 
- repeat(BooleanSupplier) - Method in class reactor.core.publisher.Flux
- 
Repeatedly subscribe to the source if the predicate returns true after completion of the previous subscription. 
- repeat(long) - Method in class reactor.core.publisher.Flux
- 
Repeatedly subscribe to the source if the predicate returns true after completion of the previous subscription. 
- repeat(long, BooleanSupplier) - Method in class reactor.core.publisher.Flux
- 
Repeatedly subscribe to the source if the predicate returns true after completion of the previous
 subscription. 
- repeat() - Method in class reactor.core.publisher.Mono
- 
Repeatedly subscribe to the source completion of the previous subscription. 
- repeat(BooleanSupplier) - Method in class reactor.core.publisher.Mono
- 
Repeatedly subscribe to the source if the predicate returns true after completion of the previous subscription. 
- repeat(long) - Method in class reactor.core.publisher.Mono
- 
Repeatedly subscribe to the source if the predicate returns true after completion of the previous subscription. 
- repeat(long, BooleanSupplier) - Method in class reactor.core.publisher.Mono
- 
Repeatedly subscribe to the source if the predicate returns true after completion of the previous
 subscription. 
- repeatWhen(Function<Flux<Long>, ? extends Publisher<?>>) - Method in class reactor.core.publisher.Flux
- 
Repeatedly subscribe to this  Flux when a companion sequence signals a number of emitted elements in
 response to the flux completion signal. 
- repeatWhen(Function<Flux<Long>, ? extends Publisher<?>>) - Method in class reactor.core.publisher.Mono
- 
Repeatedly subscribe to this  Mono when a companion sequence signals a number of emitted elements in
 response to the flux completion signal. 
- repeatWhenEmpty(Function<Flux<Long>, ? extends Publisher<?>>) - Method in class reactor.core.publisher.Mono
- 
Repeatedly subscribe to this  Mono until there is an onNext signal when a companion sequence signals a
 number of emitted elements. 
- repeatWhenEmpty(int, Function<Flux<Long>, ? extends Publisher<?>>) - Method in class reactor.core.publisher.Mono
- 
Repeatedly subscribe to this  Mono until there is an onNext signal when a companion sequence signals a
 number of emitted elements. 
- replace(AtomicReferenceFieldUpdater<F, Subscription>, F, Subscription) - Static method in class reactor.core.publisher.Operators
- 
A generic utility to atomically replace a subscription or cancel if marked by a
 singleton subscription. 
- replay() - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a hot source and cache last emitted signals for further  Subscriber. 
- replay(int) - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a connectable hot source and cache last emitted
 signals for further  Subscriber. 
- replay(Duration) - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a connectable hot source and cache last emitted signals
 for further  Subscriber. 
- replay(int, Duration) - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a connectable hot source and cache last emitted signals
 for further  Subscriber. 
- replay(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a connectable hot source and cache last emitted signals
 for further  Subscriber. 
- replay(int, Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Turn this  Flux into a connectable hot source and cache last emitted signals
 for further  Subscriber. 
- replayMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- replayMillis(int, long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- ReplayProcessor<T> - Class in reactor.core.publisher
- 
Replays all or the last N items to Subscribers. 
- reportBadRequest(long) - Static method in class reactor.core.publisher.Operators
- 
- reportMoreProduced() - Static method in class reactor.core.publisher.Operators
- 
- reportSubscriptionSet() - Static method in class reactor.core.publisher.Operators
- 
Log reportedSubscriptions 
- request(long) - Method in class reactor.core.publisher.BaseSubscriber
-  
- request(long) - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- request(long) - Method in class reactor.core.publisher.MonoProcessor
-  
- request(long) - Method in class reactor.core.publisher.Operators.DeferredSubscription
-  
- request(long) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- request(long) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- request(long) - Method in class reactor.core.publisher.UnicastProcessor
-  
- requestedFromDownstream() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- requestedFromDownstream() - Method in interface reactor.core.publisher.FluxSink
- 
The current outstanding request amount. 
- requestedFromDownstream() - Method in interface reactor.core.Trackable
- 
Deprecated. Return defined element capacity, used to drive new  Subscription request needs. 
- requestFusion(int) - Method in interface reactor.core.Fuseable.QueueSubscription
- 
Request a specific fusion mode from this QueueSubscription. 
- requestFusion(int) - Method in interface reactor.core.Fuseable.SynchronousSubscription
-  
- requestFusion(int) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- requestFusion(int) - Method in class reactor.core.publisher.UnicastProcessor
-  
- requestTask(Subscription) - Method in class reactor.core.publisher.TopicProcessor
-  
- requestTask(Subscription) - Method in class reactor.core.publisher.WorkQueueProcessor
-  
- requestUnbounded() - Method in class reactor.core.publisher.BaseSubscriber
- 
- resetFactory() - Static method in class reactor.core.scheduler.Schedulers
- 
- resetOnErrorDropped() - Static method in class reactor.core.publisher.Hooks
- 
Reset global error dropped strategy to bubbling back the error. 
- resetOnHandleError() - Static method in class reactor.core.scheduler.Schedulers
- 
- resetOnNextDropped() - Static method in class reactor.core.publisher.Hooks
- 
- resetOnOperator() - Static method in class reactor.core.publisher.Hooks
- 
Reset global "assembly" hook tracking 
- resetOnOperatorError() - Static method in class reactor.core.publisher.Hooks
- 
Reset global operator error mapping to adding as suppressed exception either data
 driven exception or error driven exception. 
- retainAll(Collection<?>) - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- retry() - Method in class reactor.core.publisher.Flux
- 
Re-subscribes to this  Flux sequence if it signals any error
 either indefinitely. 
- retry(long) - Method in class reactor.core.publisher.Flux
- 
Re-subscribes to this  Flux sequence if it signals any error
 either indefinitely or a fixed number of times. 
- retry(Predicate<Throwable>) - Method in class reactor.core.publisher.Flux
- 
Re-subscribes to this  Flux sequence if it signals any error
 and the given  Predicate matches otherwise push the error downstream. 
- retry(long, Predicate<Throwable>) - Method in class reactor.core.publisher.Flux
- 
Re-subscribes to this  Flux sequence up to the specified number of retries if it signals any
 error and the given  Predicate matches otherwise push the error downstream. 
- retry() - Method in class reactor.core.publisher.Mono
- 
Re-subscribes to this  Mono sequence if it signals any error
 either indefinitely. 
- retry(long) - Method in class reactor.core.publisher.Mono
- 
Re-subscribes to this  Mono sequence if it signals any error
 either indefinitely or a fixed number of times. 
- retry(Predicate<Throwable>) - Method in class reactor.core.publisher.Mono
- 
Re-subscribes to this  Mono sequence if it signals any error
 and the given  Predicate matches otherwise push the error downstream. 
- retry(long, Predicate<Throwable>) - Method in class reactor.core.publisher.Mono
- 
Re-subscribes to this  Mono sequence up to the specified number of retries if it signals any
 error and the given  Predicate matches otherwise push the error downstream. 
- retryWhen(Function<Flux<Throwable>, ? extends Publisher<?>>) - Method in class reactor.core.publisher.Flux
- 
Retries this  Flux when a companion sequence signals
 an item in response to this  Flux error signal 
- retryWhen(Function<Flux<Throwable>, ? extends Publisher<?>>) - Method in class reactor.core.publisher.Mono
- 
Retries this  Mono when a companion sequence signals
 an item in response to this  Mono error signal 
- run() - Method in class reactor.core.publisher.TopicProcessor
-  
- run() - Method in class reactor.core.publisher.WorkQueueProcessor
-  
- runOn(Scheduler) - Method in class reactor.core.publisher.ParallelFlux
- 
Specifies where each 'rail' will observe its incoming values with no work-stealing
 and default prefetch amount. 
- runOn(Scheduler, int) - Method in class reactor.core.publisher.ParallelFlux
- 
Specifies where each 'rail' will observe its incoming values with possibly
 work-stealing and a given prefetch amount. 
- sample(Duration) - Method in class reactor.core.publisher.Flux
- 
Emit latest value for every given period of time. 
- sample(Publisher<U>) - Method in class reactor.core.publisher.Flux
- 
Sample this  Flux and emit its latest value whenever the sampler  Publisher
 signals a value. 
- sampleFirst(Duration) - Method in class reactor.core.publisher.Flux
- 
Take a value from this  Flux then use the duration provided to skip other values. 
- sampleFirst(Function<? super T, ? extends Publisher<U>>) - Method in class reactor.core.publisher.Flux
- 
Take a value from this  Flux then use the duration provided by a
 generated Publisher to skip other values until that sampler  Publisher signals. 
- sampleFirstMillis(long) - Method in class reactor.core.publisher.Flux
- 
- sampleMillis(long) - Method in class reactor.core.publisher.Flux
- 
- sampleTimeout(Function<? super T, ? extends Publisher<U>>) - Method in class reactor.core.publisher.Flux
- 
Emit the last value from this  Flux only if there were no new values emitted
 during the time window provided by a publisher for that particular last value. 
- sampleTimeout(Function<? super T, ? extends Publisher<U>>, int) - Method in class reactor.core.publisher.Flux
- 
Emit the last value from this  Flux only if there were no newer values emitted
 during the time window provided by a publisher for that particular last value. 
- scalarSubscription(Subscriber<? super T>, T) - Static method in class reactor.core.publisher.Operators
- 
Represents a fuseable Subscription that emits a single constant value synchronously
 to a Subscriber or consumer. 
- scan(Scannable.Attr) - Method in class reactor.core.publisher.EmitterProcessor
-  
- scan(BiFunction<T, T, T>) - Method in class reactor.core.publisher.Flux
- 
Accumulate this  Flux values with an accumulator  BiFunction and
 returns the intermediate results of this function. 
- scan(A, BiFunction<A, ? super T, A>) - Method in class reactor.core.publisher.Flux
- 
Aggregate this  Flux values with the help of an accumulator  BiFunction
 and emits the intermediate results. 
- scan(Scannable.Attr) - Method in class reactor.core.publisher.FluxProcessor
-  
- scan(Scannable.Attr) - Method in class reactor.core.publisher.FluxSource
-  
- scan(Scannable.Attr) - Method in class reactor.core.publisher.MonoSource
-  
- scan(Scannable.Attr) - Method in class reactor.core.publisher.Operators.DeferredSubscription
-  
- scan(Scannable.Attr) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- scan(Scannable.Attr) - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- scan(Scannable.Attr) - Method in class reactor.core.publisher.ReplayProcessor
-  
- scan(Scannable.Attr) - Method in interface reactor.core.Scannable
- 
Return an eventual value or null for a given component state  Scannable.Attr
- scan(Scannable.Attr, Class<T>) - Method in interface reactor.core.Scannable
- 
- Scannable - Interface in reactor.core
- 
A Scannable component exposes state in a non strictly memory consistent way and
 results should be understood as best-effort hint of the underlying state. 
- Scannable.Attr - Enum in reactor.core
- 
A list of reserved keys for component state scanning 
- scanOrDefault(Scannable.Attr, T) - Method in interface reactor.core.Scannable
- 
- scanWith(Supplier<A>, BiFunction<A, ? super T, A>) - Method in class reactor.core.publisher.Flux
- 
Aggregate this  Flux values with the help of an accumulator  BiFunction
 and emits the intermediate results. 
- schedule(Runnable) - Method in interface reactor.core.scheduler.Scheduler
- 
Schedules the given task on this scheduler non-delayed execution. 
- schedule(Runnable, long, TimeUnit) - Method in interface reactor.core.scheduler.Scheduler
- 
Schedules the execution of the given task with the given delay amount. 
- schedule(Runnable) - Method in interface reactor.core.scheduler.Scheduler.Worker
- 
Schedules the task on this worker. 
- schedule(Runnable, long, TimeUnit) - Method in interface reactor.core.scheduler.Scheduler.Worker
- 
Schedules the execution of the given task with the given delay amount. 
- schedulePeriodically(Runnable, long, long, TimeUnit) - Method in interface reactor.core.scheduler.Scheduler
- 
Schedules a periodic execution of the given task with the given initial delay and period. 
- schedulePeriodically(Runnable, long, long, TimeUnit) - Method in interface reactor.core.scheduler.Scheduler.Worker
- 
Schedules a periodic execution of the given task with the given initial delay and period. 
- Scheduler - Interface in reactor.core.scheduler
- 
Provides an abstract asynchronous boundary to operators. 
- Scheduler.Worker - Interface in reactor.core.scheduler
- 
A worker representing an asynchronous boundary that executes tasks in
 a FIFO order, guaranteed non-concurrently with respect to each other. 
- Schedulers - Class in reactor.core.scheduler
- 
- Schedulers() - Constructor for class reactor.core.scheduler.Schedulers
-  
- Schedulers.Factory - Interface in reactor.core.scheduler
- 
Public factory hook to override Schedulers behavior globally 
- sequenceEqual(Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.core.publisher.Mono
- 
Returns a Mono that emits a Boolean value that indicates whether two Publisher sequences are the
 same by comparing the items emitted by each Publisher pairwise. 
- sequenceEqual(Publisher<? extends T>, Publisher<? extends T>, BiPredicate<? super T, ? super T>) - Static method in class reactor.core.publisher.Mono
- 
Returns a Mono that emits a Boolean value that indicates whether two Publisher sequences are the
 same by comparing the items emitted by each Publisher pairwise based on the results of a specified
 equality function. 
- sequenceEqual(Publisher<? extends T>, Publisher<? extends T>, BiPredicate<? super T, ? super T>, int) - Static method in class reactor.core.publisher.Mono
- 
Returns a Mono that emits a Boolean value that indicates whether two Publisher sequences are the
 same by comparing the items emitted by each Publisher pairwise based on the results of a specified
 equality function. 
- sequential() - Method in class reactor.core.publisher.ParallelFlux
- 
Merges the values from each 'rail' in a round-robin or same-order fashion and
 exposes it as a regular Publisher sequence, running with a default prefetch value
 for the rails. 
- sequential(int) - Method in class reactor.core.publisher.ParallelFlux
- 
Merges the values from each 'rail' in a round-robin or same-order fashion and
 exposes it as a regular Publisher sequence, running with a give prefetch value for
 the rails. 
- serialize() - Method in class reactor.core.publisher.FluxProcessor
- 
- serialize() - Method in interface reactor.core.publisher.FluxSink
- 
- serialize(Subscriber<? super T>) - Static method in class reactor.core.publisher.Operators
- 
- set(Subscription) - Method in class reactor.core.publisher.Operators.DeferredSubscription
- 
Atomically sets the single subscription and requests the missed amount from it. 
- set(AtomicReferenceFieldUpdater<F, Subscription>, F, Subscription) - Static method in class reactor.core.publisher.Operators
- 
A generic utility to atomically replace a subscription or cancel if marked by a
 singleton subscription or concurrently set before. 
- setCancellation(Cancellation) - Method in interface reactor.core.publisher.FluxSink
- 
- setCancellation(Cancellation) - Method in interface reactor.core.publisher.MonoSink
- 
- setFactory(Schedulers.Factory) - Static method in class reactor.core.scheduler.Schedulers
- 
- setOnce(AtomicReferenceFieldUpdater<F, Subscription>, F, Subscription) - Static method in class reactor.core.publisher.Operators
- 
Sets the given subscription once and returns true if successful, false
 if the field has a subscription already or has been cancelled. 
- setValue(O) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- share() - Method in class reactor.core.publisher.Flux
- 
Returns a new  Flux that multicasts (shares) the original  Flux. 
- share(boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
- share(ExecutorService) - Static method in class reactor.core.publisher.TopicProcessor
- 
- share(ExecutorService, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
- share(String, int) - Static method in class reactor.core.publisher.TopicProcessor
- 
- share(String, int, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using the blockingWait Strategy, passed backlog
 size, and auto-cancel settings. 
- share(ExecutorService, int) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, blockingWait Strategy
 and will auto-cancel. 
- share(ExecutorService, int, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, blockingWait Strategy
 and the auto-cancel argument. 
- share(String, int, WaitStrategy) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and will
 auto-cancel. 
- share(String, int, Supplier<E>) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and
 signal supplier. 
- share(String, int, WaitStrategy, Supplier<E>) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and
 signal supplier. 
- share(String, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and
 auto-cancel settings. 
- share(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and will
 auto-cancel. 
- share(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and
 auto-cancel settings. 
- share(ExecutorService, ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.TopicProcessor
- 
Create a new TopicProcessor using passed backlog size, wait strategy and
 auto-cancel settings. 
- share(boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
- share(ExecutorService) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
- share(ExecutorService, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
- share(String, int) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new TopicProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel. 
- share(String, int, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new TopicProcessor using the passed buffer size, blockingWait
 Strategy and the passed auto-cancel setting. 
- share(ExecutorService, int) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new TopicProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel. 
- share(ExecutorService, int, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel. 
- share(String, int, WaitStrategy) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel. 
- share(String, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, blockingWait
 Strategy and auto-cancel settings. 
- share(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size and blockingWait
 Strategy settings but will auto-cancel. 
- share(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, wait strategy
 and auto-cancel settings. 
- share(ExecutorService, ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.publisher.WorkQueueProcessor
- 
Create a new WorkQueueProcessor using the passed buffer size, wait strategy
 and auto-cancel settings. 
- shutdown() - Method in interface reactor.core.scheduler.Scheduler
- 
- shutdown() - Method in interface reactor.core.scheduler.Scheduler.Worker
- 
- shutdownNow() - Static method in class reactor.core.scheduler.Schedulers
- 
Clear any cached  Scheduler and call dispose on them. 
- Signal<T> - Class in reactor.core.publisher
- 
A domain representation of a Reactive Stream signal. 
- Signal() - Constructor for class reactor.core.publisher.Signal
-  
- signalAllWhenBlocking() - Method in class reactor.util.concurrent.WaitStrategy
- 
Implementations should signal the waiting consumers that the cursor has advanced. 
- SignalType - Enum in reactor.core.publisher
- 
Reactive Stream notification type 
- single() - Method in class reactor.core.publisher.Flux
- 
- single(T) - Method in class reactor.core.publisher.Flux
- 
- single() - Static method in class reactor.core.scheduler.Schedulers
- 
Scheduler that hosts a single-threaded ExecutorService-based worker and is
 suited for parallel work. 
- single(Scheduler) - Static method in class reactor.core.scheduler.Schedulers
- 
- singleOrEmpty() - Method in class reactor.core.publisher.Flux
- 
- sink() - Method in class reactor.core.publisher.FluxProcessor
- 
- sink(FluxSink.OverflowStrategy) - Method in class reactor.core.publisher.FluxProcessor
- 
- size() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- size() - Method in class reactor.core.publisher.UnicastProcessor
-  
- size() - Method in class reactor.util.concurrent.OpenHashSet
-  
- size() - Method in class reactor.util.function.Tuple2
- 
Return the number of elements in this Tuples. 
- size() - Method in class reactor.util.function.Tuple3
-  
- size() - Method in class reactor.util.function.Tuple4
-  
- size() - Method in class reactor.util.function.Tuple5
-  
- size() - Method in class reactor.util.function.Tuple6
-  
- size() - Method in class reactor.util.function.Tuple7
-  
- size() - Method in class reactor.util.function.Tuple8
-  
- skip(long) - Method in class reactor.core.publisher.Flux
- 
Skip next the specified number of elements from this  Flux. 
- skip(Duration) - Method in class reactor.core.publisher.Flux
- 
Skip elements from this  Flux for the given time period. 
- skip(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Skip elements from this  Flux for the given time period. 
- skipLast(int) - Method in class reactor.core.publisher.Flux
- 
Skip the last specified number of elements from this  Flux. 
- skipMillis(long) - Method in class reactor.core.publisher.Flux
- 
- skipMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- skipUntil(Predicate<? super T>) - Method in class reactor.core.publisher.Flux
- 
Skips values from this  Flux until a  Predicate returns true for the
 value. 
- skipUntilOther(Publisher<?>) - Method in class reactor.core.publisher.Flux
- 
Skip values from this  Flux until a specified  Publisher signals
 an onNext or onComplete. 
- skipWhile(Predicate<? super T>) - Method in class reactor.core.publisher.Flux
- 
Skips values from this  Flux while a  Predicate returns true for the value. 
- sleeping() - Static method in class reactor.util.concurrent.WaitStrategy
- 
Yielding strategy that uses a Thread.sleep(1) for consumers waiting on a
 barrier
 after an initially spinning. 
- small() - Static method in class reactor.util.concurrent.QueueSupplier
-  
- SMALL_BUFFER_SIZE - Static variable in class reactor.util.concurrent.QueueSupplier
- 
A small default of available slots in a given container, compromise between intensive pipelines, small
 subscribers numbers and memory use. 
- sort() - Method in class reactor.core.publisher.Flux
- 
Returns a  Flux that sorts the events emitted by source  Flux. 
- sort(Comparator<? super T>) - Method in class reactor.core.publisher.Flux
- 
Returns a  Flux that sorts the events emitted by source  Flux
 given the  Comparator function. 
- sorted(Comparator<? super T>) - Method in class reactor.core.publisher.ParallelFlux
- 
Sorts the 'rails' of this  ParallelFlux and returns a Publisher that
 sequentially picks the smallest next value from the rails. 
- sorted(Comparator<? super T>, int) - Method in class reactor.core.publisher.ParallelFlux
- 
Sorts the 'rails' of this  ParallelFlux and returns a Publisher that
 sequentially picks the smallest next value from the rails. 
- source - Variable in class reactor.core.publisher.FluxSource
-  
- source - Variable in class reactor.core.publisher.MonoSource
-  
- specificShutdown() - Method in class reactor.core.publisher.TopicProcessor
-  
- specificShutdown() - Method in class reactor.core.publisher.WorkQueueProcessor
-  
- start() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- start() - Method in interface reactor.core.scheduler.Scheduler
- 
Instructs this Scheduler to prepare itself for running tasks
 directly or through its Workers. 
- startWith(Iterable<? extends T>) - Method in class reactor.core.publisher.Flux
- 
- startWith(T...) - Method in class reactor.core.publisher.Flux
- 
Prepend the given values before this  Flux sequence. 
- startWith(Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
- stop() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. Marks the emitter as terminated without completing downstream 
- submit(E) - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- submit(E, long) - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- submit(E, long, Predicate<E>) - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- submit(E, long, TimeUnit) - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- submit(E, long, TimeUnit, Predicate<E>) - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- subOrZero(long, long) - Static method in class reactor.core.publisher.Operators
- 
Cap a substraction to 0 
- subscribe(Subscriber<? super T>) - Method in class reactor.core.publisher.DirectProcessor
-  
- subscribe(Subscriber<? super T>) - Method in class reactor.core.publisher.EmitterProcessor
-  
- subscribe() - Method in class reactor.core.publisher.Flux
- 
Start the chain and request unbounded demand. 
- subscribe(int) - Method in class reactor.core.publisher.Flux
- 
- subscribe(Consumer<? super T>) - Method in class reactor.core.publisher.Flux
- 
Subscribe a  Consumer to this  Flux that will consume all the
 sequence. 
- subscribe(Consumer<? super T>, int) - Method in class reactor.core.publisher.Flux
- 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class reactor.core.publisher.Flux
- 
Subscribe  Consumer to this  Flux that will consume all the
 sequence. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable) - Method in class reactor.core.publisher.Flux
- 
Subscribe  Consumer to this  Flux that will consume all the
 sequence. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable, Consumer<? super Subscription>) - Method in class reactor.core.publisher.Flux
- 
Subscribe  Consumer to this  Flux that will consume all the
 sequence. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable, int) - Method in class reactor.core.publisher.Flux
- 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable, Consumer<? super Subscription>, int) - Method in class reactor.core.publisher.Flux
- 
- subscribe(Subscriber<? super OUT>) - Method in class reactor.core.publisher.FluxProcessor
- 
Note: From 3.1 this is to be left unimplemented 
- subscribe(Subscriber<? super O>) - Method in class reactor.core.publisher.FluxSource
- 
Default is simply delegating and decorating with  Flux API. 
- subscribe() - Method in class reactor.core.publisher.Mono
- 
Start the chain and request unbounded demand. 
- subscribe(Consumer<? super T>) - Method in class reactor.core.publisher.Mono
- 
Subscribe a  Consumer to this  Mono that will consume all the
 sequence. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class reactor.core.publisher.Mono
- 
Subscribe  Consumer to this  Mono that will consume all the
 sequence. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable) - Method in class reactor.core.publisher.Mono
- 
Subscribe  Consumer to this  Mono that will consume all the
 sequence. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable, Consumer<? super Subscription>) - Method in class reactor.core.publisher.Mono
- 
Subscribe  Consumer to this  Mono that will consume all the
 sequence. 
- subscribe(Subscriber<? super O>) - Method in class reactor.core.publisher.MonoProcessor
-  
- subscribe(Subscriber<? super O>) - Method in class reactor.core.publisher.MonoSource
- 
Default is simply delegating and decorating with  Mono API. 
- subscribe(Subscriber<? super T>[]) - Method in class reactor.core.publisher.ParallelFlux
- 
Subscribes an array of Subscribers to this  ParallelFlux and triggers the
 execution chain for all 'rails'. 
- subscribe(Consumer<? super T>) - Method in class reactor.core.publisher.ParallelFlux
- 
Subscribes to this  ParallelFlux by providing an onNext callback and
 triggers the execution chain for all 'rails'. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class reactor.core.publisher.ParallelFlux
- 
Subscribes to this  ParallelFlux by providing an onNext and onError callback
 and triggers the execution chain for all 'rails'. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable) - Method in class reactor.core.publisher.ParallelFlux
- 
Subscribes to this  ParallelFlux by providing an onNext, onError and
 onComplete callback and triggers the execution chain for all 'rails'. 
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable, Consumer<? super Subscription>) - Method in class reactor.core.publisher.ParallelFlux
- 
Subscribes to this  ParallelFlux by providing an onNext, onError,
 onComplete and onSubscribe callback and triggers the execution chain for all
 'rails'. 
- subscribe(Subscriber<? super T>) - Method in class reactor.core.publisher.ParallelFlux
- 
- subscribe(Subscriber<? super T>) - Method in class reactor.core.publisher.ReplayProcessor
-  
- subscribe(Subscription) - Static method in class reactor.core.publisher.Signal
- 
Creates and returns a Signalof varietyType.ON_SUBSCRIBE.
 
- subscribe(Subscriber<? super E>) - Method in class reactor.core.publisher.TopicProcessor
-  
- subscribe(Subscriber<? super T>) - Method in class reactor.core.publisher.UnicastProcessor
-  
- subscribe(Subscriber<? super E>) - Method in class reactor.core.publisher.WorkQueueProcessor
-  
- subscribeOn(Scheduler) - Method in class reactor.core.publisher.Flux
- 
Run subscribe, onSubscribe and request on a supplied
  Scheduler
- subscribeOn(Scheduler) - Method in class reactor.core.publisher.Mono
- 
Run the requests to this Publisher  Mono on a given worker assigned by the supplied  Scheduler. 
- subscriber - Variable in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- SubscriberAdapter(Subscriber<? super O>) - Constructor for class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- subscribeWith(E) - Method in class reactor.core.publisher.Flux
- 
- subscribeWith(E) - Method in class reactor.core.publisher.Mono
- 
- subscription - Variable in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- success() - Method in interface reactor.core.publisher.MonoSink
- 
Complete without any value. 
- success(T) - Method in interface reactor.core.publisher.MonoSink
- 
Complete with the given value. 
- switchIfEmpty(Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
Provide an alternative if this sequence is completed without any data 
- switchIfEmpty(Mono<? extends T>) - Method in class reactor.core.publisher.Mono
- 
Provide an alternative  Mono if this mono is completed without data 
- switchMap(Function<? super T, Publisher<? extends V>>) - Method in class reactor.core.publisher.Flux
- 
- switchMap(Function<? super T, Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
- 
- switchOnError(Class<E>, Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
- switchOnError(Predicate<? super Throwable>, Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
- switchOnError(Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
- switchOnNext(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
- 
- switchOnNext(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
- 
- switchOnNext() - Static method in class reactor.core.publisher.FluxProcessor
- 
- SYNC - Static variable in interface reactor.core.Fuseable
- 
Indicates the QueueSubscription can perform sync-fusion. 
- SynchronousSink<T> - Interface in reactor.core.publisher
- 
Interface to generate signals to a bridged  Subscriber. 
- take(long) - Method in class reactor.core.publisher.Flux
- 
Take only the first N values from this  Flux. 
- take(Duration) - Method in class reactor.core.publisher.Flux
- 
Relay values from this  Flux until the given time period elapses. 
- take(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Relay values from this  Flux until the given time period elapses. 
- takeLast(int) - Method in class reactor.core.publisher.Flux
- 
Emit the last N values this  Flux emitted before its completion. 
- takeMillis(long) - Method in class reactor.core.publisher.Flux
- 
- takeMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- takeUntil(Predicate<? super T>) - Method in class reactor.core.publisher.Flux
- 
- takeUntilOther(Publisher<?>) - Method in class reactor.core.publisher.Flux
- 
- takeWhile(Predicate<? super T>) - Method in class reactor.core.publisher.Flux
- 
Relay values while a predicate returns TRUE for the values
 (checked before each value is delivered). 
- terminate(AtomicReferenceFieldUpdater<T, Throwable>, T) - Static method in class reactor.core.Exceptions
- 
Atomic utility to safely mark a volatile throwable reference with a terminal
 marker. 
- terminate(AtomicReferenceFieldUpdater<F, Subscription>, F) - Static method in class reactor.core.publisher.Operators
- 
- TERMINATED - Static variable in class reactor.core.Exceptions
- 
A singleton instance of a Throwable indicating a terminal state for exceptions,
 don't leak this! 
- then() - Method in class reactor.core.publisher.Flux
- 
Return a  Mono<Void> that completes when this  Flux completes. 
- then(Publisher<Void>) - Method in class reactor.core.publisher.Flux
- 
- then(Supplier<? extends Publisher<Void>>) - Method in class reactor.core.publisher.Flux
- 
- then() - Method in class reactor.core.publisher.Mono
- 
Return a  Mono<Void> which only replays complete and error signals
 from this  Mono. 
- then(Function<? super T, ? extends Mono<? extends R>>) - Method in class reactor.core.publisher.Mono
- 
Convert the value of  Mono to another  Mono possibly with another value type. 
- then(Mono<V>) - Method in class reactor.core.publisher.Mono
- 
Ignore element from this  Mono and transform its completion signal into the
 emission and completion signal of a provided  Mono<V>. 
- then(Supplier<? extends Mono<V>>) - Method in class reactor.core.publisher.Mono
- 
- thenEmpty(Publisher<Void>) - Method in class reactor.core.publisher.Flux
- 
Return a  Mono<Void> that waits for this  Flux to complete then
 for a supplied  Publisher<Void> to also complete. 
- thenEmpty(Publisher<Void>) - Method in class reactor.core.publisher.Mono
- 
Return a  Mono<Void> that waits for this  Mono to complete then
 for a supplied  Publisher<Void> to also complete. 
- thenMany(Publisher<V>) - Method in class reactor.core.publisher.Flux
- 
Return a  Flux that emits the sequence of the supplied  Publisher
 after this  Flux completes, ignoring this flux elements. 
- thenMany(Supplier<? extends Publisher<V>>) - Method in class reactor.core.publisher.Flux
- 
- thenMany(Publisher<V>) - Method in class reactor.core.publisher.Mono
- 
Ignore element from this mono and transform the completion signal into a
  Flux<V> that will emit elements from the provided  Publisher. 
- thenMany(Supplier<? extends Publisher<V>>) - Method in class reactor.core.publisher.Mono
- 
- THREAD_BARRIER - Static variable in interface reactor.core.Fuseable
- 
Indicates that the queue will be drained from another thread
 thus any queue-exit computation may be invalid at that point. 
- throwAlert() - Static method in class reactor.util.concurrent.WaitStrategy
- 
- throwIfFatal(Throwable) - Static method in class reactor.core.Exceptions
- 
Throws a particular Throwableonly if it belongs to a set of "fatal" error
 varieties.
 
- throwIfJvmFatal(Throwable) - Static method in class reactor.core.Exceptions
- 
Throws a particular Throwableonly if it belongs to a set of "fatal" error
 varieties native to the JVM.
 
- TimedScheduler - Interface in reactor.core.scheduler
- 
- TimedScheduler.TimedWorker - Interface in reactor.core.scheduler
- 
- timeout(Duration) - Method in class reactor.core.publisher.Flux
- 
Signal a  TimeoutException in case a per-item period fires before the
 next item arrives from this  Flux. 
- timeout(Duration, Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
Switch to a fallback  Publisher in case a per-item period
 fires before the next item arrives from this  Flux. 
- timeout(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Signal a  TimeoutException error in case a per-item
 period fires before the next item arrives from this  Flux. 
- timeout(Duration, Publisher<? extends T>, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Switch to a fallback  Publisher in case a per-item period fires before the
 next item arrives from this  Flux. 
- timeout(Publisher<U>) - Method in class reactor.core.publisher.Flux
- 
- timeout(Publisher<U>, Function<? super T, ? extends Publisher<V>>) - Method in class reactor.core.publisher.Flux
- 
- timeout(Publisher<U>, Function<? super T, ? extends Publisher<V>>, Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
Switch to a fallback  Publisher in case a first item from this  Flux has
 not been emitted before the given  Publisher emits. 
- timeout(Duration) - Method in class reactor.core.publisher.Mono
- 
Signal a  TimeoutException in case an item doesn't arrive before the given period. 
- timeout(Duration, Mono<? extends T>) - Method in class reactor.core.publisher.Mono
- 
Switch to a fallback  Mono in case an item doesn't arrive before the given period. 
- timeout(Duration, Scheduler) - Method in class reactor.core.publisher.Mono
- 
Signal a  TimeoutException error in case an item doesn't arrive before the given period. 
- timeout(Duration, Mono<? extends T>, Scheduler) - Method in class reactor.core.publisher.Mono
- 
Switch to a fallback  Mono in case an item doesn't arrive before the given period. 
- timeout(Publisher<U>) - Method in class reactor.core.publisher.Mono
- 
- timeout(Publisher<U>, Mono<? extends T>) - Method in class reactor.core.publisher.Mono
- 
Switch to a fallback  Publisher in case the  item from this  Mono has
 not been emitted before the given  Publisher emits. 
- timeoutMillis(long) - Method in class reactor.core.publisher.Flux
- 
- timeoutMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- timeoutMillis(long, Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
- 
- timeoutMillis(long, Publisher<? extends T>, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- timeoutMillis(long) - Method in class reactor.core.publisher.Mono
- 
- timeoutMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Mono
- 
- timeoutMillis(long, Mono<? extends T>) - Method in class reactor.core.publisher.Mono
- 
- timeoutMillis(long, Mono<? extends T>, TimedScheduler) - Method in class reactor.core.publisher.Mono
- 
- timer() - Static method in class reactor.core.scheduler.Schedulers
- 
- timestamp() - Method in class reactor.core.publisher.Flux
- 
Emit a  Tuple2 pair of T1  Long current system time in
 millis and T2  T associated data for each item from this  Flux
- timestamp(TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- timestamp(Scheduler) - Method in class reactor.core.publisher.Flux
- 
Emit a  Tuple2 pair of T1  Long current system time in
 millis and T2  T associated data for each item from this  Flux
- timestamp() - Method in class reactor.core.publisher.Mono
- 
Emit a  Tuple2 pair of T1  Long current system time in
 millis and T2  T associated data for the eventual item from this  Mono
- timestamp(TimedScheduler) - Method in class reactor.core.publisher.Mono
- 
- timestamp(Scheduler) - Method in class reactor.core.publisher.Mono
- 
Emit a  Tuple2 pair of T1  Long current system time in
 millis and T2  T associated data for the eventual item from this  Mono
- toArray() - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- toArray(T1[]) - Method in interface reactor.core.Fuseable.QueueSubscription
-  
- toArray() - Method in class reactor.util.function.Tuple2
- 
Turn this Tuples into a plain Object array. 
- toArray() - Method in class reactor.util.function.Tuple3
-  
- toArray() - Method in class reactor.util.function.Tuple4
-  
- toArray() - Method in class reactor.util.function.Tuple5
-  
- toArray() - Method in class reactor.util.function.Tuple6
-  
- toArray() - Method in class reactor.util.function.Tuple7
-  
- toArray() - Method in class reactor.util.function.Tuple8
-  
- toFuture() - Method in class reactor.core.publisher.Mono
- 
- toIterable() - Method in class reactor.core.publisher.Flux
- 
Transform this  Flux into a lazy  Iterable blocking on next calls. 
- toIterable(long) - Method in class reactor.core.publisher.Flux
- 
Transform this  Flux into a lazy  Iterable blocking on next calls. 
- toIterable(long, Supplier<Queue<T>>) - Method in class reactor.core.publisher.Flux
- 
Transform this  Flux into a lazy  Iterable blocking on next calls. 
- toList() - Method in class reactor.util.function.Tuple2
- 
Turn this Tuples into a plain Object list. 
- TopicProcessor<E> - Class in reactor.core.publisher
- 
An implementation of a RingBuffer backed message-passing Processor implementing publish-subscribe with async event
 loops. 
- toStream() - Method in class reactor.core.publisher.Flux
- 
Transform this  Flux into a lazy  Stream blocking on next calls. 
- toStream(int) - Method in class reactor.core.publisher.Flux
- 
Transform this  Flux into a lazy  Stream blocking on next calls. 
- toString() - Method in class reactor.core.publisher.BaseSubscriber
-  
- toString() - Method in class reactor.core.publisher.BlockingSink
- 
Deprecated. 
- toString() - Method in class reactor.core.publisher.Flux
-  
- toString() - Method in class reactor.core.publisher.FluxSource
-  
- toString() - Method in class reactor.core.publisher.Mono
-  
- toString() - Method in class reactor.core.publisher.MonoSource
-  
- toString() - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- toString() - Method in class reactor.core.publisher.Signal
-  
- toString() - Method in enum reactor.core.publisher.SignalType
-  
- toString() - Method in class reactor.util.function.Tuple2
-  
- trace(String) - Method in interface reactor.util.Logger
- 
Log a message at the TRACE level. 
- trace(String, Object...) - Method in interface reactor.util.Logger
- 
Log a message at the TRACE level according to the specified format
 and arguments. 
- trace(String, Throwable) - Method in interface reactor.util.Logger
- 
Log an exception (throwable) at the TRACE level with an
 accompanying message. 
- Trackable - Interface in reactor.core
- 
- transform(Function<? super Flux<T>, ? extends Publisher<V>>) - Method in class reactor.core.publisher.Flux
- 
Transform this  Flux in order to generate a target  Flux. 
- transform(Function<? super Mono<T>, ? extends Publisher<V>>) - Method in class reactor.core.publisher.Mono
- 
Transform this  Mono in order to generate a target  Mono. 
- transform(Function<? super ParallelFlux<T>, ParallelFlux<U>>) - Method in class reactor.core.publisher.ParallelFlux
- 
Allows composing operators, in assembly time, on top of this  ParallelFlux
 and returns another  ParallelFlux with composed features. 
- tryOnNext(T) - Method in interface reactor.core.Fuseable.ConditionalSubscriber
- 
Try consuming the value and return true if successful. 
- Tuple2<T1,T2> - Class in reactor.util.function
- 
A tuple that holds two values 
- Tuple3<T1,T2,T3> - Class in reactor.util.function
- 
A tuple that holds three values 
- Tuple4<T1,T2,T3,T4> - Class in reactor.util.function
- 
A tuple that holds four values 
- Tuple5<T1,T2,T3,T4,T5> - Class in reactor.util.function
- 
A tuple that holds five values 
- Tuple6<T1,T2,T3,T4,T5,T6> - Class in reactor.util.function
- 
A tuple that holds six values 
- Tuple7<T1,T2,T3,T4,T5,T6,T7> - Class in reactor.util.function
- 
A tuple that holds seven values 
- Tuple8<T1,T2,T3,T4,T5,T6,T7,T8> - Class in reactor.util.function
- 
A tuple that holds eight values 
- Tuples - Class in reactor.util.function
- 
A Tuples is an immutable  Collection of objects, each of which can be of an arbitrary type. 
- unbounded() - Static method in class reactor.util.concurrent.QueueSupplier
-  
- unbounded(int) - Static method in class reactor.util.concurrent.QueueSupplier
- 
Returns an unbounded, linked-array-based Queue. 
- undefined() - Static method in class reactor.core.publisher.MutableNextSignal
- 
- UnicastProcessor<T> - Class in reactor.core.publisher
- 
A Processor implementation that takes a custom queue and allows
 only a single subscriber. 
- UnicastProcessor(Queue<T>) - Constructor for class reactor.core.publisher.UnicastProcessor
-  
- UnicastProcessor(Queue<T>, Disposable) - Constructor for class reactor.core.publisher.UnicastProcessor
-  
- UnicastProcessor(Queue<T>, Consumer<? super T>, Disposable) - Constructor for class reactor.core.publisher.UnicastProcessor
-  
- UNSPECIFIED - Static variable in interface reactor.core.Trackable
- 
Deprecated. Returned value when a given component does not provide access to the requested
 trait 
- untilOther(Publisher<?>) - Method in class reactor.core.publisher.Mono
- 
Subscribe to this Mono and another Publisher, which will be used as a trigger for
 the emission of this Mono's element. 
- untilOtherDelayError(Publisher<?>) - Method in class reactor.core.publisher.Mono
- 
Subscribe to this Mono and another Publisher, which will be used as a trigger for
 the emission of this Mono's element, mapped through a provided function. 
- unwrap(Throwable) - Static method in class reactor.core.Exceptions
- 
- upstream() - Method in class reactor.core.publisher.BaseSubscriber
-  
- upstream() - Method in class reactor.core.publisher.DirectProcessor
-  
- upstream() - Method in class reactor.core.publisher.EmitterProcessor
- 
Deprecated. 
- upstream() - Method in class reactor.core.publisher.FluxSource
-  
- upstream() - Method in class reactor.core.publisher.MonoProcessor
-  
- upstream() - Method in class reactor.core.publisher.MonoSource
-  
- upstream() - Method in class reactor.core.publisher.Operators.DeferredSubscription
-  
- upstream() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-  
- upstream() - Method in class reactor.core.publisher.Operators.SubscriberAdapter
- 
Deprecated. 
- upstream() - Method in class reactor.core.publisher.ReplayProcessor
-  
- upstream() - Method in class reactor.core.publisher.UnicastProcessor
-  
- upstream() - Method in interface reactor.core.Receiver
- 
Deprecated. Return the direct source of data, Supports reference. 
- upstreamCount() - Method in interface reactor.core.MultiReceiver
- 
Deprecated. 
- upstreams() - Method in interface reactor.core.MultiReceiver
- 
Deprecated. Return the connected sources of data. 
- using(Callable<? extends D>, Function<? super D, ? extends Publisher<? extends T>>, Consumer<? super D>) - Static method in class reactor.core.publisher.Flux
- 
Uses a resource, generated by a supplier for each individual Subscriber, while streaming the values from a
 Publisher derived from the same resource and makes sure the resource is released if the sequence terminates or
 the Subscriber cancels. 
- using(Callable<? extends D>, Function<? super D, ? extends Publisher<? extends T>>, Consumer<? super D>, boolean) - Static method in class reactor.core.publisher.Flux
- 
Uses a resource, generated by a supplier for each individual Subscriber, while streaming the values from a
 Publisher derived from the same resource and makes sure the resource is released if the sequence terminates or
 the Subscriber cancels. 
- using(Callable<? extends D>, Function<? super D, ? extends Mono<? extends T>>, Consumer<? super D>, boolean) - Static method in class reactor.core.publisher.Mono
- 
Uses a resource, generated by a supplier for each individual Subscriber, while streaming the value from a
 Mono derived from the same resource and makes sure the resource is released if the
 sequence terminates or
 the Subscriber cancels. 
- using(Callable<? extends D>, Function<? super D, ? extends Mono<? extends T>>, Consumer<? super D>) - Static method in class reactor.core.publisher.Mono
- 
Uses a resource, generated by a supplier for each individual Subscriber, while streaming the value from a
 Mono derived from the same resource and makes sure the resource is released if the
 sequence terminates or
 the Subscriber cancels. 
- validate(Subscription, Subscription) - Static method in class reactor.core.publisher.Operators
- 
Check Subscription current state and cancel new Subscription if different null, returning true if
 ready to subscribe. 
- validate(long) - Static method in class reactor.core.publisher.Operators
- 
- validate(Subscriber<?>[]) - Method in class reactor.core.publisher.ParallelFlux
- 
Validates the number of subscribers and returns true if their number matches the
 parallelism level of this ParallelFlux. 
- value - Variable in class reactor.core.publisher.Operators.MonoSubscriber
-  
- valueOf(String) - Static method in enum reactor.core.publisher.BlockingSink.Emission
- 
Deprecated. Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum reactor.core.publisher.BufferOverflowStrategy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum reactor.core.publisher.FluxSink.OverflowStrategy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum reactor.core.publisher.SignalType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum reactor.core.Scannable.Attr
- 
Returns the enum constant of this type with the specified name. 
- values() - Static method in enum reactor.core.publisher.BlockingSink.Emission
- 
Deprecated. Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum reactor.core.publisher.BufferOverflowStrategy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum reactor.core.publisher.FluxSink.OverflowStrategy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum reactor.core.publisher.SignalType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum reactor.core.Scannable.Attr
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- waitFor(long, LongSupplier, Runnable) - Method in class reactor.util.concurrent.WaitStrategy
- 
Wait for the given sequence to be available. 
- WaitStrategy - Class in reactor.util.concurrent
- 
Strategy employed to wait for specific  LongSupplier values with various spinning strategies. 
- WaitStrategy() - Constructor for class reactor.util.concurrent.WaitStrategy
-  
- warn(String) - Method in interface reactor.util.Logger
- 
Log a message at the WARN level. 
- warn(String, Object...) - Method in interface reactor.util.Logger
- 
Log a message at the WARN level according to the specified format
 and arguments. 
- warn(String, Throwable) - Method in interface reactor.util.Logger
- 
Log an exception (throwable) at the WARN level with an
 accompanying message. 
- when(Mono<? extends T1>, Mono<? extends T2>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- when(Mono<? extends T1>, Mono<? extends T2>, BiFunction<? super T1, ? super T2, ? extends O>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- when(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- when(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- when(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>, Mono<? extends T5>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- when(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>, Mono<? extends T5>, Mono<? extends T6>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- when(Iterable<? extends Publisher<Void>>) - Static method in class reactor.core.publisher.Mono
- 
Aggregate given void publishers into a new a Mono that will be
 fulfilled when all of the given Monos have been fulfilled. 
- when(Iterable<? extends Mono<?>>, Function<? super Object[], ? extends R>) - Static method in class reactor.core.publisher.Mono
- 
Aggregate given monos into a new a Mono that will be fulfilled when all of the given Monos have been fulfilled. 
- when(Publisher<Void>...) - Static method in class reactor.core.publisher.Mono
- 
Aggregate given void publisher into a new a Mono that will be fulfilled
 when all of the given sources have been fulfilled. 
- when(Function<? super Object[], ? extends R>, Mono<?>...) - Static method in class reactor.core.publisher.Mono
- 
Aggregate given monos into a new a Mono that will be fulfilled when all of the given Monos have been fulfilled. 
- whenDelayError(Mono<? extends T1>, Mono<? extends T2>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- whenDelayError(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Mono Monos
 have been fulfilled. 
- whenDelayError(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- whenDelayError(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>, Mono<? extends T5>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- whenDelayError(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>, Mono<? extends T5>, Mono<? extends T6>) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- whenDelayError(Iterable<? extends Publisher<Void>>) - Static method in class reactor.core.publisher.Mono
- 
Aggregate given void publishers into a new a Mono that will be
 fulfilled when all of the given sources have been fulfilled. 
- whenDelayError(Iterable<? extends Mono<?>>, Function<? super Object[], ? extends R>) - Static method in class reactor.core.publisher.Mono
- 
Aggregate given monos into a new a Mono that will be fulfilled when all of the given Monos have been fulfilled. 
- whenDelayError(Publisher<Void>...) - Static method in class reactor.core.publisher.Mono
- 
Merge given void publishers into a new a Mono that will be fulfilled when
 all of the given sources have been fulfilled. 
- whenDelayError(Function<? super Object[], ? extends R>, Mono<?>...) - Static method in class reactor.core.publisher.Mono
- 
Merge given monos into a new a Mono that will be fulfilled when all of the given Monos
 have been fulfilled. 
- window() - Method in class reactor.core.publisher.Flux
- 
- window(int) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given  maxSize
 count and starting from
 the first item. 
- window(int, int) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given  skip
 count,
 starting from
 the first item. 
- window(Publisher<?>) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into continuous, non-overlapping windows
 where the window boundary is signalled by another  Publisher
- window(Publisher<U>, Function<? super U, ? extends Publisher<V>>) - Method in class reactor.core.publisher.Flux
- 
- window(Duration) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into continuous, non-overlapping windows delimited by a given period. 
- window(Duration, Duration) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given  timeshift
 period, starting from the first item. 
- window(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into continuous, non-overlapping windows delimited by a given period. 
- window(Duration, Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given  timeshift
 period, starting from the first item. 
- window(int, Duration) - Method in class reactor.core.publisher.Flux
- 
- windowMillis(long) - Method in class reactor.core.publisher.Flux
- 
- windowMillis(long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- windowMillis(long, long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- windowMillis(int, long) - Method in class reactor.core.publisher.Flux
- 
- windowMillis(int, long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- windowTimeout(int, Duration) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given  maxSize number
 of items, starting from the first item. 
- windowTimeout(int, Duration, Scheduler) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given  maxSize number
 of items, starting from the first item. 
- windowTimeoutMillis(int, long) - Method in class reactor.core.publisher.Flux
- 
- windowTimeoutMillis(int, long, TimedScheduler) - Method in class reactor.core.publisher.Flux
- 
- windowUntil(Predicate<T>) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given
 predicate. 
- windowUntil(Predicate<T>, boolean) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given
 predicate. 
- windowUntil(Predicate<T>, boolean, int) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux delimited by the given
 predicate and using a prefetch. 
- windowWhen(Publisher<U>, Function<? super U, ? extends Publisher<V>>) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into potentially overlapping windows controlled by items of a
 start  Publisher and end  Publisher derived from the start values. 
- windowWhile(Predicate<T>) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux windows that stay open
 while a given predicate matches the source elements. 
- windowWhile(Predicate<T>, int) - Method in class reactor.core.publisher.Flux
- 
Split this  Flux sequence into multiple  Flux windows that stay open
 while a given predicate matches the source elements. 
- withLatestFrom(Publisher<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class reactor.core.publisher.Flux
- 
- WorkQueueProcessor<E> - Class in reactor.core.publisher
- 
An implementation of a RingBuffer backed message-passing Processor implementing work-queue distribution with
 async event loops. 
- wrap(Subscriber<IN>, Publisher<OUT>) - Static method in class reactor.core.publisher.FluxProcessor
- 
- wrap(Publisher<? extends I>) - Static method in class reactor.core.publisher.FluxSource
- 
- wrap(Publisher<? extends I>) - Static method in class reactor.core.publisher.MonoSource
-