- accept(Subscriber<? super T>) - Method in class reactor.core.publisher.Signal
-
- actual - Variable in class reactor.core.publisher.Operators.MonoSubscriber
-
- actual() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- actual() - Method in class reactor.core.publisher.UnicastProcessor
-
- actuals() - Method in interface reactor.core.Scannable
-
- add(T) - Method in interface reactor.core.Fuseable.QueueSubscription
-
- add(T) - Method in class reactor.util.concurrent.OpenHashSet
-
- addAll(Collection<? extends T>) - Method in interface reactor.core.Fuseable.QueueSubscription
-
- addAndGet(AtomicLongFieldUpdater<T>, T, long) - Static method in class reactor.core.publisher.Operators
-
Concurrent addition bound to Long.MAX_VALUE.
- addCap(long, long) - Static method in class reactor.core.publisher.Operators
-
Cap an addition to Long.MAX_VALUE
- addThrowable(AtomicReferenceFieldUpdater<T, Throwable>, T, Throwable) - Static method in class reactor.core.Exceptions
-
Update an empty atomic reference with the given exception, or combine further added
exceptions together as suppressed exceptions under a root Throwable with
the "Multiple exceptions"
message, if the atomic reference already holds
one.
- alert() - Static method in class reactor.util.concurrent.WaitStrategy
-
- all(Predicate<? super T>) - Method in class reactor.core.publisher.Flux
-
Emit a single boolean true if all values of this sequence match
the
Predicate
.
- and(Mono<? extends T2>) - Method in class reactor.core.publisher.Mono
-
Combine the result from this mono and another into a
Tuple2
.
- and(Mono<? extends T2>, BiFunction<? super T, ? super T2, ? extends O>) - Method in class reactor.core.publisher.Mono
-
Combine the result from this mono and another into an arbitrary O
object,
as defined by the provided combinator
function.
- and(Function<T, Mono<? extends T2>>) - Method in class reactor.core.publisher.Mono
-
Wait for the result from this mono, use it to create a second mono via the
provided
rightGenerator
function and combine both results into a
Tuple2
.
- and(Function<T, Mono<? extends T2>>, BiFunction<T, T2, O>) - Method in class reactor.core.publisher.Mono
-
Wait for the result from this mono, use it to create a second mono via the
provided rightGenerator
function and combine both results into an arbitrary
O
object, as defined by the provided combinator
function.
- ANY - Static variable in interface reactor.core.Fuseable
-
Indicates the QueueSubscription should decide what fusion it performs (input only).
- any(Predicate<? super T>) - Method in class reactor.core.publisher.Flux
-
Emit a single boolean true if any of the values of this
Flux
sequence match
the predicate.
- apply(Object) - Method in class reactor.util.function.Tuples
-
- argumentIsNullException() - Static method in class reactor.core.Exceptions
-
- as(Function<? super Flux<T>, P>) - Method in class reactor.core.publisher.Flux
-
Transform this
Flux
into a target type.
- as(Function<? super Mono<T>, P>) - Method in class reactor.core.publisher.Mono
-
Transform this
Mono
into a target type.
- as(Subscription) - Static method in class reactor.core.publisher.Operators
-
Returns the subscription as QueueSubscription if possible or null.
- as(Function<? super ParallelFlux<T>, U>) - Method in class reactor.core.publisher.ParallelFlux
-
Perform a fluent transformation to a value via a converter function which receives
this ParallelFlux.
- ASYNC - Static variable in interface reactor.core.Fuseable
-
Indicates the QueueSubscription can perform only async-fusion.
- autoConnect() - Method in class reactor.core.publisher.ConnectableFlux
-
- autoConnect(int) - Method in class reactor.core.publisher.ConnectableFlux
-
- autoConnect(int, Consumer<? super Disposable>) - Method in class reactor.core.publisher.ConnectableFlux
-
Connects this
ConnectableFlux
to the upstream source when the specified amount of
Subscriber
subscribes and calls the supplied consumer with a runnable that allows disconnecting.
- awaitOnSubscribe() - Method in class reactor.core.publisher.Flux
-
Intercepts the onSubscribe call and makes sure calls to Subscription methods
only happen after the child Subscriber has returned from its onSubscribe method.
- awaitOnSubscribe() - Method in class reactor.core.publisher.Mono
-
Intercepts the onSubscribe call and makes sure calls to Subscription methods
only happen after the child Subscriber has returned from its onSubscribe method.
- 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.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.UnicastProcessor
-
- 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
-
Propagate an exception to a subscriber 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
-
- collect(Supplier<E>, BiConsumer<E, ? super T>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a user-defined container,
by applying a collector
BiConsumer
taking the container and each element.
- collect(Collector<? super T, A, ? extends R>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a container,
by applying a Java 8 Stream API
Collector
The collected result will be emitted when this sequence completes.
- 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
-
Collect all elements emitted by this
Flux
into a
List
that is
emitted by the resulting
Mono
when this sequence completes.
- collectMap(Function<? super T, ? extends K>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a hashed
Map
that is
emitted by the resulting
Mono
when this sequence completes.
- collectMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a hashed
Map
that is
emitted by the resulting
Mono
when this sequence completes.
- collectMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<Map<K, V>>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a user-defined
Map
that is
emitted by the resulting
Mono
when this sequence completes.
- collectMultimap(Function<? super T, ? extends K>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a
multimap
that is
emitted by the resulting
Mono
when this sequence completes.
- collectMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a
multimap
that is
emitted by the resulting
Mono
when this sequence completes.
- collectMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<Map<K, Collection<V>>>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a user-defined
multimap
that is
emitted by the resulting
Mono
when this sequence completes.
- collectSortedList() - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
until this sequence completes,
and then sort them in natural order into a
List
that is emitted by the
resulting
Mono
.
- collectSortedList(Comparator<? super T>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
until this sequence completes,
and then sort them using a
Comparator
into a
List
that is emitted
by the resulting
Mono
.
- 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 recently published value from each
of the
Publisher
sources.
- 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 recently published value from each
of the
Publisher
sources.
- 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 recently published value from each
of two
Publisher
sources.
- 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 recently published value from each
of three
Publisher
sources.
- 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 recently published value from each
of four
Publisher
sources.
- 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 recently published value from each
of five
Publisher
sources.
- 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 recently published value from each
of six
Publisher
sources.
- 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 recently published value from each
of the
Publisher
sources provided in an
Iterable
.
- 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 recently published value from each
of the
Publisher
sources provided in an
Iterable
.
- 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 Signal
of variety Type.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
type.
- 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
-
Concatenate all sources provided in an
Iterable
, forwarding elements
emitted by the sources downstream.
- concat(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concat(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concat(Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources provided as a vararg, forwarding elements emitted by the
sources downstream.
- concatDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concatDelayError(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concatDelayError(Publisher<? extends Publisher<? extends T>>, boolean, int) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concatDelayError(Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources provided as a vararg, forwarding elements emitted by the
sources downstream.
- concatMap(Function<? super T, ? extends Publisher<? extends V>>) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- concatMap(Function<? super T, ? extends Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- 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
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends V>>, boolean, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- 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
concatenating 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
concatenating 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
-
- 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
-
- 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() - 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, boolean) - Static method in class reactor.core.publisher.EmitterProcessor
-
- create(Consumer<? super FluxSink<T>>) - Static method in class reactor.core.publisher.Flux
-
Programmatically create a
Flux
with the capability of emitting multiple
elements in a synchronous or asynchronous manner through the
FluxSink
API.
- create(Consumer<? super FluxSink<T>>, FluxSink.OverflowStrategy) - Static method in class reactor.core.publisher.Flux
-
Programmatically create a
Flux
with the capability of emitting multiple
elements in a synchronous or asynchronous manner 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.
- 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.
- 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.
- 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>) - Method in interface reactor.core.scheduler.Schedulers.Factory
-
- 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 pool size, initialized to the number of processors available to the runtime
on init (but with a minimum value of 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 single value if this mono is completed without any data
- defer(Supplier<? extends Publisher<T>>) - Static method in class reactor.core.publisher.Flux
-
Lazily supply a
Publisher
every time a
Subscription
is made on the
resulting
Flux
, so the actual source instantiation is deferred until each
subscribe and the
Supplier
can create a subscriber-specific instance.
- 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) - Static method in class reactor.core.publisher.Mono
-
Create a Mono which delays an onNext signal by a given
duration
on a default Scheduler and completes.
- delay(Duration, Scheduler) - Static method in class reactor.core.publisher.Mono
-
Create a Mono which delays an onNext signal by a given
duration
on a provided
Scheduler
and completes.
- delayElement(Duration) - Method in class reactor.core.publisher.Mono
-
- delayElement(Duration, Scheduler) - 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
-
- 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
-
- 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.
- delayUntil(Function<? super T, ? extends Publisher<?>>) - Method in class reactor.core.publisher.Mono
-
Subscribe to this
Mono
and another
Publisher
that is generated from
this Mono's element and which will be used as a trigger for relaying said element.
- delayUntilOther(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.
- dematerialize() - Method in class reactor.core.publisher.Flux
-
An operator working only if this
Flux
emits onNext, onError or onComplete
Signal
instances, transforming these
materialized
signals into
real signals on the
Subscriber
.
- dematerialize() - Method in class reactor.core.publisher.Mono
-
An operator working only if this
Mono
emits onNext, onError or onComplete
Signal
instances, transforming these
materialized
signals into
real signals on the
Subscriber
.
- 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.Disposable
-
Cancel or dispose the underlying task or resource.
- dispose() - Method in class reactor.core.publisher.BaseSubscriber
-
- 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.
- distinct() - Method in class reactor.core.publisher.Flux
-
For each
Subscriber
, track elements from this
Flux
that have been
seen and filter out duplicates.
- distinct(Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
-
For each
Subscriber
, track elements from this
Flux
that have been
seen and filter out duplicates, as compared by a key extracted through the user
provided
Function
.
- distinctUntilChanged() - Method in class reactor.core.publisher.Flux
-
Filter out subsequent repetitions of an element (that is, if they arrive right after
one another).
- distinctUntilChanged(Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
-
Filter out subsequent repetitions of an element (that is, if they arrive right after
one another), as compared by a key extracted through the user provided
Function
.
- doAfterTerminate(Runnable) - Method in class reactor.core.publisher.Flux
-
Add behavior (side-effect) 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
-
Add behavior 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.
- doComplete() - Method in class reactor.core.publisher.TopicProcessor
-
- doComplete() - Method in class reactor.core.publisher.WorkQueueProcessor
-
- 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
-
Add behavior (side-effect) triggered
afterthe
Flux
terminates for any reason,
including cancellation.
- doFinally(Consumer<SignalType>) - Method in class reactor.core.publisher.Mono
-
Add behavior triggering
after the
Mono
terminates for any reason,
including cancellation.
- doOnCancel(Runnable) - Method in class reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
is cancelled.
- doOnCancel(Runnable) - Method in class reactor.core.publisher.Mono
-
Add behavior 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
-
Add behavior (side-effect) 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
-
Add behavior (side-effects) triggered 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
-
Add behavior triggered 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
-
Add behavior (side-effect) triggered when the
Flux
completes with an error.
- doOnError(Class<E>, Consumer<? super E>) - Method in class reactor.core.publisher.Flux
-
Add behavior (side-effect) 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
-
Add behavior (side-effect) triggered when the
Flux
completes with an error matching the given exception.
- doOnError(Consumer<? super Throwable>) - Method in class reactor.core.publisher.Mono
-
Add behavior triggered when the
Mono
completes with an error.
- doOnError(Class<E>, Consumer<? super E>) - Method in class reactor.core.publisher.Mono
-
Add behavior 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
-
Add behavior triggered when the
Mono
completes with an error matching the given predicate.
- 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
-
Add behavior (side-effect) triggered when the
Flux
emits an item.
- doOnNext(Consumer<? super T>) - Method in class reactor.core.publisher.Mono
-
Add behavior 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
-
Add behavior (side-effect) triggering a
LongConsumer
when this
Flux
receives any request.
- 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
-
Add behavior (side-effect) triggered when the
Flux
is subscribed.
- doOnSubscribe(Consumer<? super Subscription>) - Method in class reactor.core.publisher.Mono
-
Add behavior triggered when the
Mono
is subscribed.
- doOnSubscribe(Consumer<? super Subscription>) - Method in class reactor.core.publisher.ParallelFlux
-
Call the specified callback when a 'rail' receives a Subscription from its
upstream.
- doOnSuccess(Consumer<? super T>) - Method in class reactor.core.publisher.Mono
-
Add behavior triggered when the
Mono
completes successfully.
- doOnTerminate(Runnable) - Method in class reactor.core.publisher.Flux
-
Add behavior (side-effect) 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
-
Add behavior 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.
- 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
-
Return the number of active
Subscriber
or -1 if untracked.
- downstreamCount() - Method in class reactor.core.publisher.ReplayProcessor
-
- downstreamCount() - Method in class reactor.core.publisher.UnicastProcessor
-
- 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 source value against the given
Predicate
.
- filter(Predicate<? super T>) - Method in class reactor.core.publisher.Mono
-
If this
Mono
is valued, test the result 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.
- first(Mono<? extends T>...) - Static method in class reactor.core.publisher.Mono
-
Pick the first
Mono
to emit any signal (value, empty completion or error)
and replay that signal, effectively behaving like the fastest of these competing
sources.
- first(Iterable<? extends Mono<? extends T>>) - Static method in class reactor.core.publisher.Mono
-
Pick the first available 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
-
Pick the first
Publisher
to emit any signal (onNext/onError/onComplete) and
replay all signals from that
Publisher
, effectively behaving like the
fastest of these competing sources.
- firstEmitting(Iterable<? extends Publisher<? extends I>>) - Static method in class reactor.core.publisher.Flux
-
Pick the first
Publisher
to emit any signal (onNext/onError/onComplete) and
replay all signals from that
Publisher
, effectively behaving like the
fastest of these competing sources.
- firstEmittingWith(Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
-
Pick the first
Publisher
between this
Flux
and another publisher
to emit any signal (onNext/onError/onComplete) and replay all signals from that
Publisher
, effectively behaving like the fastest of these competing sources.
- flatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
through merging,
which allow them to interleave.
- flatMap(Function<? super T, ? extends Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
through merging,
which allow them to interleave.
- flatMap(Function<? super T, ? extends Publisher<? extends V>>, int, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
through merging,
which allow them to interleave.
- flatMap(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.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
through merging,
which allow them to interleave.
- flatMap(Function<? super T, ? extends Mono<? extends R>>) - Method in class reactor.core.publisher.Mono
-
Transform the item emitted by this
Mono
asynchronously, returning the
value emitted by another
Mono
(possibly changing the value type).
- 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 elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
through merging,
which allow them to 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 signal-specific Publishers,
then forward the applicable Publisher's emissions into the returned
Flux
.
- flatMapSequential(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, but merge them in
the order of their source element.
- flatMapSequential(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, but merge them in
the order of their source element.
- flatMapSequential(Function<? super T, ? extends Publisher<? extends R>>, int, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, but merge them in
the order of their source element.
- flatMapSequentialDelayError(Function<? super T, ? extends Publisher<? extends R>>, int, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, but merge them in
the order of their source element.
- 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' (one per CPU core)
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 in a 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 in a 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 array.
- 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 its value using the provided
Callable
.
- fromCompletionStage(CompletionStage<? extends T>) - Static method in class reactor.core.publisher.Mono
-
- fromDirect(Publisher<? extends I>) - Static method in class reactor.core.publisher.Mono
-
Convert a
Publisher
to a
Mono
without any cardinality check
(ie this method doesn't check if the source is already a Mono, nor cancels the
source past the first element).
- 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
that completes empty once the provided
Runnable
has
been executed.
- 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 its value using the provided
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, directly allowing a new value to be sent if
it didn't.
- Fuseable.QueueSubscription<T> - Interface in reactor.core
-
Support contract for queue-fusion based optimizations on 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 their items in a pull fashion, thus avoiding the request-accounting
overhead in many cases.
- 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 one of the provided names matches the
operator underlying 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 one of the provided names is contained in the
operator's underlying 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 propagates termination events.
- ignoreElements() - Method in class reactor.core.publisher.Flux
-
Ignores onNext signals (dropping them) and only propagate termination events.
- ignoreElements(Publisher<T>) - Static method in class reactor.core.publisher.Mono
-
Create a new
Mono
that ignores elements from the source (dropping them),
but completes when the source completes.
- 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
-
String representation that can be adjusted for higher-cardinality Tuples in order
to show all values hold.
- 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 long values starting with 0 and incrementing at
specified time intervals on the global timer.
- interval(Duration, Duration) - Static method in class reactor.core.publisher.Flux
-
Create a
Flux
that emits long values starting with 0 and incrementing at
specified time intervals, after an initial delay, on the global timer.
- interval(Duration, Scheduler) - Static method in class reactor.core.publisher.Flux
-
Create a
Flux
that emits long values starting with 0 and incrementing at
specified time intervals, on the specified
Scheduler
.
- interval(Duration, Duration, Scheduler) - Static method in class reactor.core.publisher.Flux
-
Create a
Flux
that emits long values starting with 0 and incrementing at
specified time intervals, after an initial delay, on the specified
Scheduler
.
- isAlert(Throwable) - Static method in class reactor.util.concurrent.WaitStrategy
-
Test if exception is alert
- isBubbling(Throwable) - Static method in class reactor.core.Exceptions
-
Check if the given exception is a
bubbled
wrapped exception.
- isCancel(Throwable) - Static method in class reactor.core.Exceptions
-
- 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
-
Indicates whether this MonoProcessor
has been interrupted via cancellation.
- 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.
- isComplete(Object) - Static method in class reactor.core.publisher.Signal
-
Check if an arbitrary Object represents a COMPLETE
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.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 MonoProcessor
has been completed with an error.
- isError(Object) - Static method in class reactor.core.publisher.Signal
-
Check if a arbitrary Object represents an ERROR
Signal
.
- isErrorCallbackNotImplemented(Throwable) - Static method in class reactor.core.Exceptions
-
Check if the given error is a
callback not implemented
exception, in which case its
cause
will be the propagated
error that couldn't be processed.
- isErrorEnabled() - Method in interface reactor.util.Logger
-
Is the logger instance enabled for the ERROR level?
- isInfoEnabled() - Method in interface reactor.util.Logger
-
Is the logger instance enabled for the INFO level?
- isOnComplete() - Method in class reactor.core.publisher.Signal
-
Indicates whether this signal represents an onComplete
event.
- isOnError() - Method in class reactor.core.publisher.Signal
-
Indicates whether this signal represents an onError
event.
- isOnNext() - Method in class reactor.core.publisher.Signal
-
Indicates whether this signal represents an onNext
event.
- isOnSubscribe() - Method in class reactor.core.publisher.Signal
-
Indicates whether this signal represents an onSubscribe
event.
- isOverflow(Throwable) - Static method in class reactor.core.Exceptions
-
Check if the given exception represents an
overflow
.
- 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
-
- isSuccess() - Method in class reactor.core.publisher.MonoProcessor
-
Indicates whether this MonoProcessor
has been successfully completed a value.
- 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
-
Indicates whether this MonoProcessor
has been terminated by the
source producer with a success or an error.
- isTerminated() - Method in class reactor.core.publisher.ReplayProcessor
-
- isTerminated() - Method in class reactor.core.publisher.UnicastProcessor
-
- 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 emitted value against the given
Class
type.
- onAssembly(Flux<T>) - Static method in class reactor.core.publisher.Flux
-
To be used by custom operators: invokes assembly
Hooks
pointcut given a
Flux
, potentially returning a new
Flux
.
- onAssembly(ConnectableFlux<T>) - Static method in class reactor.core.publisher.Flux
-
- onAssembly(Mono<T>) - Static method in class reactor.core.publisher.Mono
-
To be used by custom operators: invokes assembly
Hooks
pointcut given a
Mono
, potentially returning a 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 to 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 to 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 to 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 to 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 to 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 to 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 to 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 to 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.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.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
-
An unexpected exception is about to be dropped, and it additionally
masks another one due to callback failure.
- onErrorDropped(Throwable) - Static method in class reactor.core.publisher.Operators
-
An unexpected exception is about to be dropped.
- onErrorMap(Function<? super Throwable, ? extends Throwable>) - Method in class reactor.core.publisher.Flux
-
Transform any error emitted by this
Flux
by synchronously applying a function to it.
- onErrorMap(Class<E>, Function<? super E, ? extends Throwable>) - Method in class reactor.core.publisher.Flux
-
Transform an error emitted by this
Flux
by synchronously applying a function
to it if the error matches the given type.
- onErrorMap(Predicate<? super Throwable>, Function<? super Throwable, ? extends Throwable>) - Method in class reactor.core.publisher.Flux
-
Transform an error emitted by this
Flux
by synchronously applying a function
to it if the error matches the given predicate.
- onErrorMap(Function<? super Throwable, ? extends Throwable>) - Method in class reactor.core.publisher.Mono
-
Transform any error emitted by this
Mono
by synchronously applying a function to it.
- onErrorMap(Class<E>, Function<? super E, ? extends Throwable>) - Method in class reactor.core.publisher.Mono
-
Transform an error emitted by this
Mono
by synchronously applying a function
to it if the error matches the given type.
- onErrorMap(Predicate<? super Throwable>, Function<? super Throwable, ? extends Throwable>) - Method in class reactor.core.publisher.Mono
-
Transform an error emitted by this
Mono
by synchronously applying a function
to it if the error matches the given predicate.
- 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, using a function to
choose the fallback depending on the error.
- onErrorResume(Class<E>, Function<? super E, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
-
Subscribe to a fallback publisher when an error matching the given type
occurs, using a function to choose the fallback depending on the error.
- onErrorResume(Predicate<? super Throwable>, Function<? super Throwable, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
-
Subscribe to a fallback publisher when an error matching a given predicate
occurs.
- onErrorResume(Function<? super Throwable, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
-
Subscribe to a fallback publisher when any error occurs, using a function to
choose the fallback depending on the error.
- onErrorResume(Class<E>, Function<? super E, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
-
Subscribe to a fallback publisher when an error matching the given type
occurs, using a function to choose the fallback depending on the error.
- onErrorResume(Predicate<? super Throwable>, Function<? super Throwable, ? extends Mono<? extends T>>) - Method in class reactor.core.publisher.Mono
-
Subscribe to a fallback publisher when an error matching a given predicate
occurs.
- onErrorReturn(T) - Method in class reactor.core.publisher.Flux
-
Simply emit a captured fallback value when any error is observed on this
Flux
.
- onErrorReturn(Class<E>, T) - Method in class reactor.core.publisher.Flux
-
Simply emit a captured fallback value when an error of the specified type is
observed on this
Flux
.
- onErrorReturn(Predicate<? super Throwable>, T) - Method in class reactor.core.publisher.Flux
-
Simply emit a captured fallback value when 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(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
-
Configure a global chain of "assembly" hooks 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.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 might also 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.
- operatorStacktrace() - Method in class reactor.core.publisher.Hooks.OperatorHook
-
Enable operator stack recorder that captures a declaration stack whenever an
operator is instantiated.
- or(Mono<? extends T>) - Method in class reactor.core.publisher.Mono
-
Emit the first available result from this mono or the other mono.
- 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.
- reduce(BiFunction<T, T, T>) - Method in class reactor.core.publisher.Flux
-
Reduce the values from this
Flux
sequence into an single object of the same
type than the emitted items.
- reduce(A, BiFunction<A, ? super T, A>) - Method in class reactor.core.publisher.Flux
-
Reduce the values from this
Flux
sequence into an single object matching the
type of a seed value.
- 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
-
Reduce the values from this
Flux
sequence into an single object matching the
type of a lazily supplied seed value.
- 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 and indefinitely subscribe to the source upon 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 numRepeat times.
- 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 and indefinitely subscribe to the source upon 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 numRepeat times.
- 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 emits 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 emits 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
as long as the current subscription to this
Mono
completes empty and the companion
Publisher
produces an onNext signal.
- repeatWhenEmpty(int, Function<Flux<Long>, ? extends Publisher<?>>) - Method in class reactor.core.publisher.Mono
-
Repeatedly subscribe to this
Mono
as long as the current subscription to this
Mono
completes empty and the companion
Publisher
produces an onNext signal.
- replace(AtomicReferenceFieldUpdater<F, Subscription>, F, Subscription) - Static method in class reactor.core.publisher.Operators
-
A generic utility to atomically replace a subscription or cancel the replacement
if the current subscription is marked as already cancelled (as in
Operators.cancelledSubscription()
).
- 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
.
- 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
-
- request(long) - Method in class reactor.core.publisher.BaseSubscriber
-
- 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.UnicastProcessor
-
- requestedFromDownstream() - Method in interface reactor.core.publisher.FluxSink
-
The current outstanding request amount.
- 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.
- 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, indefinitely.
- retry(long) - Method in class reactor.core.publisher.Flux
-
Re-subscribes to this
Flux
sequence if it signals any error, for a fixed
number of times.
- retry(Predicate<? super Throwable>) - Method in class reactor.core.publisher.Flux
-
Re-subscribes to this
Flux
sequence if it signals any error
that matches the given
Predicate
, otherwise push the error downstream.
- retry(long, Predicate<? super 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 that match the given
Predicate
, otherwise push the error downstream.
- retry() - Method in class reactor.core.publisher.Mono
-
Re-subscribes to this
Mono
sequence if it signals any error, indefinitely.
- retry(long) - Method in class reactor.core.publisher.Mono
-
Re-subscribes to this
Mono
sequence if it signals any error, for a fixed
number of times.
- retry(Predicate<? super Throwable>) - Method in class reactor.core.publisher.Mono
-
Re-subscribes to this
Mono
sequence if it signals any error
that matches the given
Predicate
, otherwise push the error downstream.
- retry(long, Predicate<? super 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 that match the given
Predicate
, 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
-
Sample this
Flux
by periodically emitting an item corresponding to that
Flux
latest emitted value within the periodical time window.
- sample(Publisher<U>) - Method in class reactor.core.publisher.Flux
-
Sample this
Flux
by emitting an item corresponding to that
Flux
latest emitted value whenever a companion sampler
Publisher
signals a value.
- sampleFirst(Duration) - Method in class reactor.core.publisher.Flux
-
Repeatedly take a value from this
Flux
then skip the values that follow
within a given duration.
- sampleFirst(Function<? super T, ? extends Publisher<U>>) - Method in class reactor.core.publisher.Flux
-
Repeatedly take a value from this
Flux
then skip the values that follow
before the next signal from a companion sampler
Publisher
.
- sampleTimeout(Function<? super T, ? extends Publisher<U>>) - Method in class reactor.core.publisher.Flux
-
Emit the latest value from this
Flux
only if there were no new values emitted
during the window defined by a companion
Publisher
derived from that particular
value.
- sampleTimeout(Function<? super T, ? extends Publisher<U>>, int) - Method in class reactor.core.publisher.Flux
-
Emit the latest value from this
Flux
only if there were no new values emitted
during the window defined by a companion
Publisher
derived from that particular
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
-
Reduce this
Flux
values with an accumulator
BiFunction
and
also emit the intermediate results of this function.
- scan(A, BiFunction<A, ? super T, A>) - Method in class reactor.core.publisher.Flux
-
Reduce this
Flux
values with an accumulator
BiFunction
and
also emit the intermediate results of this function.
- 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.MonoProcessor
-
- 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.ReplayProcessor
-
- scan(Scannable.Attr) - Method in interface reactor.core.Scannable
-
Introspect a component's specific state
attribute
, returning a
best effort value or null if the attribute doesn't make sense for that particular
component.
- scan(Scannable.Attr, Class<T>) - Method in interface reactor.core.Scannable
-
Introspect a component's specific state
attribute
, returning a
best effort value casted to the provided class, or null if the attribute doesn't
make sense for that particular component.
- 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
-
Introspect a component's specific state
attribute
, returning a
best effort casted value or the provided default if the attribute doesn't make
sense for that particular component.
- scanWith(Supplier<A>, BiFunction<A, ? super T, A>) - Method in class reactor.core.publisher.Flux
-
Reduce this
Flux
values with the help of an accumulator
BiFunction
and also emits the intermediate results.
- schedule(Runnable) - Method in interface reactor.core.scheduler.Scheduler
-
Schedules the non-delayed execution of the given task on this scheduler.
- 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 for immediate execution 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(Subscriber<? super T>) - Static method in class reactor.core.publisher.Operators
-
Safely gate a
Subscriber
by making sure onNext signals are delivered
sequentially (serialized).
- 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 the replacement
if current subscription is marked as cancelled (as in
Operators.cancelledSubscription()
)
or was concurrently updated before.
- 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
-
Set the value internally, without impacting request tracking state.
- 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.
- 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 signal types
- single() - Method in class reactor.core.publisher.Flux
-
- single(T) - Method in class reactor.core.publisher.Flux
-
Expect and emit a single item from this
Flux
source and emit a default
value for an empty source, but signal an
IndexOutOfBoundsException
for a
source with more than one element.
- 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
-
Expect and emit a single item from this
Flux
source, and accept an empty
source but signal an
IndexOutOfBoundsException
for a source with more than
one element.
- 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 the specified number of elements from the beginning of this
Flux
then
emit the remaining elements.
- skip(Duration) - Method in class reactor.core.publisher.Flux
-
Skip elements from this
Flux
emitted within the specified initial duration.
- skip(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
-
Skip elements from this
Flux
emitted within the specified initial duration,
as measured on the provided
Scheduler
.
- skipLast(int) - Method in class reactor.core.publisher.Flux
-
Skip a specified number of elements at the end of this
Flux
sequence.
- 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
-
Sort elements from this
Flux
by collecting and sorting them in the background
then emitting the sorted sequence once this sequence completes.
- sort(Comparator<? super T>) - Method in class reactor.core.publisher.Flux
-
Sort elements from this
Flux
using a
Comparator
function, by
collecting and sorting elements in the background then emitting the sorted sequence
once this sequence completes.
- 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 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
-
- subOrZero(long, long) - Static method in class reactor.core.publisher.Operators
-
Cap a subtraction 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
-
Subscribe to this
Flux
and request unbounded demand.
- subscribe(Consumer<? super T>) - Method in class reactor.core.publisher.Flux
-
Subscribe a
Consumer
to this
Flux
that will consume all the
elements in the sequence.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class reactor.core.publisher.Flux
-
Subscribe to this
Flux
with a
Consumer
that will consume all the
elements in the sequence, as well as a
Consumer
that will handle errors.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable) - Method in class reactor.core.publisher.Flux
-
Subscribe
Consumer
to this
Flux
that will respectively consume all the
elements in the sequence, handle errors and react to completion.
- 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 respectively consume all the
elements in the sequence, handle errors, react to completion, and request upon subscription.
- 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
-
Subscribe to this
Mono
and request unbounded demand, then represent the
subscription as a
MonoProcessor
(allowing to block, cancel as well as
many other operations).
- 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 to this
Mono
with a
Consumer
that will consume all the
elements in the sequence, as well as a
Consumer
that will handle errors.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Runnable) - Method in class reactor.core.publisher.Mono
-
Subscribe
Consumer
to this
Mono
that will respectively consume all the
elements in the sequence, handle errors and react to completion.
- 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 respectively consume all the
elements in the sequence, handle errors, react to completion, and request upon subscription.
- 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() - Method in class reactor.core.publisher.ParallelFlux
-
Subscribes 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 Signal
of variety Type.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
-
- subscribeOn(Scheduler) - Method in class reactor.core.publisher.Mono
-
- subscribeWith(E) - Method in class reactor.core.publisher.Flux
-
- subscribeWith(E) - Method in class reactor.core.publisher.Mono
-
- 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
-
Switch to an alternative
Publisher
if this sequence is completed without any data.
- switchIfEmpty(Mono<? extends T>) - Method in class reactor.core.publisher.Mono
-
Fallback to 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
-
- switchOnNext(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
-
Creates a
Flux
that mirrors the most recently emitted
Publisher
,
forwarding its data until a new
Publisher
comes in in the source.
- switchOnNext(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
-
Creates a
Flux
that mirrors the most recently emitted
Publisher
,
forwarding its data until a new
Publisher
comes in in the source.
- 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
, if available.
- take(Duration) - Method in class reactor.core.publisher.Flux
-
Relay values from this
Flux
until the specified
Duration
elapses.
- take(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
-
Relay values from this
Flux
until the specified
Duration
elapses,
as measured on the specified
Scheduler
.
- takeLast(int) - Method in class reactor.core.publisher.Flux
-
Emit the last N values this
Flux
emitted before its completion.
- 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 from this
Flux
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(Mono<V>) - Method in class reactor.core.publisher.Flux
-
Let this
Flux
complete then play signals from a provided
Mono
.
- then() - Method in class reactor.core.publisher.Mono
-
Return a
Mono<Void>
which only replays complete and error signals
from this
Mono
.
- then(Mono<V>) - Method in class reactor.core.publisher.Mono
-
Let this
Mono
complete then play another 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
-
- thenMany(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.
- throwIfFatal(Throwable) - Static method in class reactor.core.Exceptions
-
Throws a particular Throwable
only if it belongs to a set of "fatal" error
varieties.
- throwIfJvmFatal(Throwable) - Static method in class reactor.core.Exceptions
-
Throws a particular Throwable
only if it belongs to a set of "fatal" error
varieties native to the JVM.
- timeout(Duration) - Method in class reactor.core.publisher.Flux
-
Propagate a
TimeoutException
as soon as no item is emitted within the
given
Duration
from the previous emission (or the subscription for the first item).
- timeout(Duration, Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
-
Switch to a fallback
Flux
as soon as no item is emitted within the
given
Duration
from the previous emission (or the subscription for the first item).
- timeout(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
-
Propagate a
TimeoutException
as soon as no item is emitted within the
given
Duration
from the previous emission (or the subscription for the first
item), as measured by the specified
Scheduler
.
- timeout(Duration, Publisher<? extends T>, Scheduler) - Method in class reactor.core.publisher.Flux
-
Switch to a fallback
Flux
as soon as no item is emitted within the
given
Duration
from the previous emission (or the subscription for the
first item), as measured on the specified
Scheduler
.
- 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
-
Signal a
TimeoutException
in case the first item from this
Flux
has
not been emitted before the
firstTimeout
Publisher
emits, and whenever
each subsequent elements is not emitted before a
Publisher
generated from
the latest element signals.
- 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 the first item from this
Flux
has
not been emitted before the
firstTimeout
Publisher
emits, and whenever
each subsequent elements is not emitted before a
Publisher
generated from
the latest element signals.
- timeout(Duration) - Method in class reactor.core.publisher.Mono
-
- timeout(Duration, Mono<? extends T>) - Method in class reactor.core.publisher.Mono
-
Switch to a fallback
Mono
in case no item arrives within the given
Duration
.
- 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,
as measured on the provided
Scheduler
.
- 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,
as measured on the provided
Scheduler
.
- 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.
- timestamp() - Method in class reactor.core.publisher.Flux
-
Emit a
Tuple2
pair of T1 the current clock time in
millis (as a
Long
measured by the
parallel
Scheduler) and T2 the emitted data (as a
T
), for each item from this
Flux
.
- timestamp(Scheduler) - Method in class reactor.core.publisher.Flux
-
Emit a
Tuple2
pair of T1 the current clock time in
millis (as a
Long
measured by the provided
Scheduler
) and T2
the emitted data (as a
T
), for each item from this
Flux
.
- timestamp() - Method in class reactor.core.publisher.Mono
-
If this
Mono
is valued, emit a
Tuple2
pair of
T1 the current clock time in millis (as a
Long
measured by the
parallel
Scheduler) and T2 the emitted data (as a
T
).
- timestamp(Scheduler) - Method in class reactor.core.publisher.Mono
-
If this
Mono
is valued, emit a
Tuple2
pair of
T1 the current clock time in millis (as a
Long
measured by the
provided
Scheduler
) and T2 the emitted data (as a
T
).
- 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
-
- toIterable(long) - Method in class reactor.core.publisher.Flux
-
- toIterable(long, Supplier<Queue<T>>) - Method in class reactor.core.publisher.Flux
-
- 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
-
- toStream(int) - Method in class reactor.core.publisher.Flux
-
- toString() - Method in class reactor.core.publisher.BaseSubscriber
-
- 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.Signal
-
- toString() - Method in enum reactor.core.publisher.SignalType
-
- toString() - Method in class reactor.util.function.Tuple2
-
A Tuple String representation is the comma separated list of values, enclosed
in square brackets.
- 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.
- 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.
- 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 Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple2
.
- 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 Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values as defined by the combinator function.
- when(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>) - Static method in class reactor.core.publisher.Mono
-
Merge given monos into a new Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple3
.
- 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 Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple4
.
- 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 Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple5
.
- 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 Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple6
.
- when(Iterable<? extends Publisher<Void>>) - Static method in class reactor.core.publisher.Mono
-
Aggregate given void publishers into a new Mono that will be
fulfilled when all of the given Publishers 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 Mono that will be fulfilled when all of the given Monos have been fulfilled, aggregating their values according to the provided combinator function.
- when(Publisher<Void>...) - Static method in class reactor.core.publisher.Mono
-
Aggregate given void publishers into a new 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 Mono that will be fulfilled when all of the given Monos have been fulfilled, aggregating their values according to the provided combinator function.
- whenDelayError(Mono<? extends T1>, Mono<? extends T2>) - Static method in class reactor.core.publisher.Mono
-
Merge given monos into a new Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple2
and delaying errors.
- whenDelayError(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>) - Static method in class reactor.core.publisher.Mono
-
Merge given monos into a new Mono that will be fulfilled when all of the given Mono Monos
have been fulfilled, aggregating their values into a
Tuple3
and delaying errors.
- 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 Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple4
and delaying errors.
- 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 Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple5
and delaying errors.
- 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 Mono that will be fulfilled when all of the given Monos
have been fulfilled, aggregating their values into a
Tuple6
and delaying errors.
- whenDelayError(Iterable<? extends Publisher<Void>>) - Static method in class reactor.core.publisher.Mono
-
Aggregate given void publishers into a new 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 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 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 Mono that will be fulfilled when all of the
given Monos have been fulfilled, aggregating their values according to
the provided combinator function and delaying errors.
- window(int) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows containing
maxSize
elements (or less for the final window) and starting from the first item.
- window(int, int) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows of size
maxSize
, that each open every
skip
elements in the source.
- 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(Duration) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into continuous, non-overlapping windows that open
for a
timespan
Duration
(as measured on the
parallel
Scheduler).
- window(Duration, Duration) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows that open
for a given
timespan
Duration
, after which it closes with onComplete.
- window(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into continuous, non-overlapping windows that open
for a
timespan
Duration
(as measured on the provided
Scheduler
).
- window(Duration, Duration, Scheduler) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows that open
for a given
timespan
Duration
, after which it closes with onComplete.
- windowTimeout(int, Duration) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows containing
maxSize
elements (or less for the final window) and starting from the first item.
- windowTimeout(int, Duration, Scheduler) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows containing
maxSize
elements (or less for the final window) and starting from the first item.
- windowUntil(Predicate<T>) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows delimited by the
given predicate.
- windowUntil(Predicate<T>, boolean) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows delimited by the
given predicate.
- windowUntil(Predicate<T>, boolean, int) - Method in class reactor.core.publisher.Flux
-
Split this
Flux
sequence into multiple
Flux
windows 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
-
Combine the most recently emitted values from both this
Flux
and another
Publisher
through a
BiFunction
and emits the result.
- 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
-