- 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(Duration, Scheduler) - 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(int, Duration, Scheduler) - 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
.
- cache(Duration) - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signals for further
Subscriber
, with an expiry timeout.
- cache(Duration, Scheduler) - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signals for further
Subscriber
, with an expiry timeout.
- cache(Function<? super T, Duration>, Function<Throwable, Duration>, Supplier<Duration>) - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signal for further
Subscriber
, with an expiry timeout (TTL) that depends on said signal.
- cache(Function<? super T, Duration>, Function<Throwable, Duration>, Supplier<Duration>, Scheduler) - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signal for further
Subscriber
, with an expiry timeout (TTL) that depends on said signal.
- cacheLast() - Static method in class reactor.core.publisher.ReplayProcessor
-
- cacheLastOrDefault(T) - Static method in class reactor.core.publisher.ReplayProcessor
-
- canAppearAfterOnSubscribe(Subscription) - Static method in class reactor.core.publisher.Operators
-
Check whether the provided
Subscription
is the one used to satisfy Spec's ยง1.9 rule
before signalling an error.
- 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
-
Deprecated.
- CANCELLED - Static variable in class reactor.core.Scannable.Attr
-
A
Boolean
attribute indicating whether or not a downstream component
has interrupted consuming this scanned component, e.g., a cancelled
subscription.
- 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
.
- CAPACITY - Static variable in class reactor.core.Scannable.Attr
-
Return an an
Integer
capacity when no
Scannable.Attr.PREFETCH
is defined or
when an arbitrary maximum limit is applied to the backlog capacity of the
scanned component.
- capacity(Queue) - Static method in class reactor.util.concurrent.Queues
-
Return the capacity of a given
Queue
in a best effort fashion.
- CAPACITY_UNSURE - Static variable in class reactor.util.concurrent.Queues
-
- 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.Queues
-
Calculate the next power of 2, greater than or equal to x.
- checkpoint() - Method in class reactor.core.publisher.Flux
-
Activate traceback (full 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 traceback (assembly marker) for this particular
Flux
by giving it a description that
will be reflected in the assembly traceback in case of an error upstream of the
checkpoint.
- checkpoint(String, boolean) - Method in class reactor.core.publisher.Flux
-
Activate traceback (full assembly tracing or the lighter assembly marking depending on the
forceStackTrace
option).
- checkpoint() - Method in class reactor.core.publisher.Mono
-
Activate traceback (full 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 traceback (assembly marker) for this particular
Mono
by giving it a description that
will be reflected in the assembly traceback in case of an error upstream of the
checkpoint.
- checkpoint(String, boolean) - Method in class reactor.core.publisher.Mono
-
Activate traceback (full assembly tracing or the lighter assembly marking depending on the
forceStackTrace
option).
- checkpoint() - Method in class reactor.core.publisher.ParallelFlux
-
Activate traceback (full 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 traceback (assembly marker) for this particular
ParallelFlux
by giving it a description that
will be reflected in the assembly traceback in case of an error upstream of the
checkpoint.
- checkpoint(String, boolean) - Method in class reactor.core.publisher.ParallelFlux
-
Activate traceback (full assembly tracing or the lighter assembly marking depending on the
forceStackTrace
option).
- clear() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- clear() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- 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
-
Terminate the sequence successfully, generating an
onComplete
signal.
- 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 interface reactor.core.publisher.Signal
-
Creates and returns a Signal
of variety Type.COMPLETE
.
- complete(Context) - Static method in interface reactor.core.publisher.Signal
-
Creates and returns a
Signal
of variety
Type.COMPLETE
, associated
with a specific
Context
.
- complete() - Method in interface reactor.core.publisher.SynchronousSink
-
- composite() - Static method in class reactor.core.Disposables
-
- composite(Disposable...) - Static method in class reactor.core.Disposables
-
- composite(Iterable<? extends Disposable>) - Static method in class reactor.core.Disposables
-
- 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, ? 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.
- 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).
- concatWithValues(T...) - Method in class reactor.core.publisher.Flux
-
Concatenates the values to the end of the
Flux
- 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
-
- Context - Interface in reactor.util.context
-
A key/value store that is propagated between components such as operators via the
context protocol.
- ContextView - Interface in reactor.util.context
-
A read-only view of a collection of key/value pairs that is propagated between components
such as operators via the context protocol.
- contextWrite(ContextView) - Method in class reactor.core.publisher.Flux
-
Enrich the
Context
visible from downstream for the benefit of upstream
operators, by making all values from the provided
ContextView
visible on top
of pairs from downstream.
- contextWrite(Function<Context, Context>) - Method in class reactor.core.publisher.Flux
-
Enrich the
Context
visible from downstream for the benefit of upstream
operators, by applying a
Function
to the downstream
Context
.
- contextWrite(ContextView) - Method in class reactor.core.publisher.Mono
-
Enrich the
Context
visible from downstream for the benefit of upstream
operators, by making all values from the provided
ContextView
visible on top
of pairs from downstream.
- contextWrite(Function<Context, Context>) - Method in class reactor.core.publisher.Mono
-
Enrich the
Context
visible from downstream for the benefit of upstream
operators, by applying a
Function
to the downstream
Context
.
- convertToFluxBypassingHooks(Publisher<T>) - Static method in class reactor.core.publisher.Hooks
-
- convertToMonoBypassingHooks(Publisher<T>, boolean) - Static method in class reactor.core.publisher.Hooks
-
- copy() - Method in interface reactor.util.retry.Retry.RetrySignal
-
An immutable copy of this
Retry.RetrySignal
which is guaranteed to give a consistent view
of the state at the time at which this method is invoked.
- CorePublisher<T> - Interface in reactor.core
-
- CoreSubscriber<T> - Interface in reactor.core
-
A
Context
aware subscriber which has relaxed rules for ยง1.3 and ยง3.9
compared to the original
Subscriber
from Reactive Streams.
- 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() - Static method in class reactor.core.publisher.ReplayProcessor
-
- create(int) - Static method in class reactor.core.publisher.ReplayProcessor
-
- create(int, boolean) - Static method in class reactor.core.publisher.ReplayProcessor
-
- create() - Static method in class reactor.core.publisher.UnicastProcessor
-
- create(Queue<E>) - Static method in class reactor.core.publisher.UnicastProcessor
-
- create(Queue<E>, Disposable) - Static method in class reactor.core.publisher.UnicastProcessor
-
- create(Queue<E>, Consumer<? super E>, Disposable) - Static method in class reactor.core.publisher.UnicastProcessor
-
- createSizeAndTimeout(int, Duration) - Static method in class reactor.core.publisher.ReplayProcessor
-
- createSizeAndTimeout(int, Duration, Scheduler) - Static method in class reactor.core.publisher.ReplayProcessor
-
- createTimeout(Duration) - Static method in class reactor.core.publisher.ReplayProcessor
-
- createTimeout(Duration, Scheduler) - Static method in class reactor.core.publisher.ReplayProcessor
-
- createWorker() - Method in interface reactor.core.scheduler.Scheduler
-
Creates a worker of this Scheduler.
- currentContext() - Method in interface reactor.core.CoreSubscriber
-
Request a
Context
from dependent components which can include downstream
operators during subscribing or a terminal
Subscriber
.
- currentContext() - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- currentContext() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- currentContext() - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
- currentContext() - Method in interface reactor.core.publisher.FluxSink
-
Return the current subscriber
Context
.
- currentContext() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
- currentContext() - Method in interface reactor.core.publisher.MonoSink
-
Return the current subscriber
Context
.
- currentContext() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- currentContext() - Method in interface reactor.core.publisher.SynchronousSink
-
Return the current subscriber
Context
.
- currentContext() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- currentSubscriberCount() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- currentSubscriberCount() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- currentSubscriberCount() - Method in interface reactor.core.publisher.Sinks.Empty
-
Get how many
Subscribers
are currently subscribed to the sink.
- currentSubscriberCount() - Method in interface reactor.core.publisher.Sinks.Many
-
Get how many
Subscribers
are currently subscribed to the sink.
- currentSubscriberCount() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- debug(String) - Method in interface reactor.util.Logger
-
Log a message at the DEBUG level.
- debug(String, Object...) - Method in interface reactor.util.Logger
-
Log a message at the DEBUG level according to the specified format
and arguments.
- debug(String, Throwable) - Method in interface reactor.util.Logger
-
Log an exception (throwable) at the DEBUG level with an
accompanying message.
- decorateExecutorService(Scheduler, ScheduledExecutorService) - Static method in class reactor.core.scheduler.Schedulers
-
This method is aimed at
Scheduler
implementors, enabling custom implementations
that are backed by a
ScheduledExecutorService
to also have said executors
decorated (ie.
- DEFAULT_BOUNDED_ELASTIC_QUEUESIZE - Static variable in class reactor.core.scheduler.Schedulers
-
Default maximum number of enqueued tasks PER THREAD for the global
Schedulers.boundedElastic()
Scheduler
,
initialized by system property
reactor.schedulers.defaultBoundedElasticQueueSize
and falls back to
a bound of 100 000 tasks per backing thread.
- DEFAULT_BOUNDED_ELASTIC_SIZE - Static variable in class reactor.core.scheduler.Schedulers
-
Default maximum size for the global
Schedulers.boundedElastic()
Scheduler
, initialized
by system property
reactor.schedulers.defaultBoundedElasticSize
and falls back to 10 x number
of processors available to the runtime on init.
- DEFAULT_POOL_SIZE - Static variable in class reactor.core.scheduler.Schedulers
-
Default pool size, initialized by system property reactor.schedulers.defaultPoolSize
and falls back to the number of processors available to the runtime on init.
- 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
- defaultValue() - Method in class reactor.core.Scannable.Attr
-
Meaningful and always applicable default value for the attribute, returned
instead of null when a specific value hasn't been defined for a
component.
- 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
-
- deferContextual(Function<ContextView, ? 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
Function
can create a subscriber-specific instance.
- deferContextual(Function<ContextView, ? extends Mono<? extends T>>) - Static method in class reactor.core.publisher.Mono
-
- DeferredSubscription() - Constructor for class reactor.core.publisher.Operators.DeferredSubscription
-
- deferWithContext(Function<Context, ? extends Publisher<T>>) - Static method in class reactor.core.publisher.Flux
-
- deferWithContext(Function<Context, ? extends Mono<? extends T>>) - Static method in class reactor.core.publisher.Mono
-
- 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.
- DELAY_ERROR - Static variable in class reactor.core.Scannable.Attr
-
Delay_Error exposes a
Boolean
whether the scanned component
actively supports error delaying if it manages a backlog instead of fast
error-passing which might drop pending backlog.
- 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
-
- delaySequence(Duration) - Method in class reactor.core.publisher.Flux
-
- delaySequence(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.Flux
-
Subscribe to this
Flux
and generate a
Publisher
from each of this
Flux elements, each acting as a trigger for relaying said element.
- 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.
- delete(Object) - Method in interface reactor.util.context.Context
-
Return a new
Context
that will resolve all existing keys except the
removed one,
key
.
- 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
.
- directAllOrNothing() - Method in interface reactor.core.publisher.Sinks.MulticastSpec
-
A
Sinks.Many
with the following characteristics:
Multicast
Without
Subscriber
: fail fast on
tryEmitNext
.
Backpressure : notify the caller with
Sinks.EmitResult.FAIL_OVERFLOW
if any of the subscribers
cannot process an element, failing fast and backing off from emitting the element at all (all or nothing).
- directBestEffort() - Method in interface reactor.core.publisher.Sinks.MulticastSpec
-
- DirectProcessor<T> - Class in reactor.core.publisher
-
- disableContextLossTracking() - Static method in class reactor.core.publisher.Hooks
-
- disableMetrics() - Static method in class reactor.core.scheduler.Schedulers
-
- discard(O) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
Discard the given value, generally this.value field.
- Disposable - Interface in reactor.core
-
Indicates that a task or resource can be cancelled/disposed.
- Disposable.Composite - Interface in reactor.core
-
- Disposable.Swap - Interface in reactor.core
-
A
Disposable
container that allows updating/replacing its inner Disposable
atomically and with respect of disposing the container itself.
- Disposables - Class in reactor.core
-
- dispose() - Method in interface reactor.core.Disposable.Composite
-
Atomically mark the container as
disposed
, clear it and then
dispose all the previously contained Disposables.
- 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
-
Deprecated.
- dispose() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
- dispose() - Method in interface reactor.core.scheduler.Scheduler
-
Instructs this Scheduler to release all resources and reject
any new tasks to be executed.
- dispose() - Method in class reactor.core.scheduler.Schedulers.Snapshot
-
- disposed() - Static method in class reactor.core.Disposables
-
- 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
.
- distinct(Function<? super T, ? extends V>, Supplier<C>) - 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
and by the
add method
of the
Collection
supplied (typically a
Set
).
- distinct(Function<? super T, ? extends V>, Supplier<C>, BiPredicate<C, V>, Consumer<C>) - 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 applying a
BiPredicate
on
an arbitrary user-supplied
<C>
store and 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
using equality.
- distinctUntilChanged(Function<? super T, ? extends V>, BiPredicate<? super V, ? super 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
and then comparing keys with the supplied
BiPredicate
.
- doAfterRetry(Consumer<Retry.RetrySignal>) - Method in class reactor.util.retry.RetryBackoffSpec
-
Add synchronous behavior to be executed after the retry trigger is emitted in
the companion publisher.
- doAfterRetry(Consumer<Retry.RetrySignal>) - Method in class reactor.util.retry.RetrySpec
-
Add synchronous behavior to be executed after the retry trigger is emitted in
the companion publisher.
- doAfterRetryAsync(Function<Retry.RetrySignal, Mono<Void>>) - Method in class reactor.util.retry.RetryBackoffSpec
-
Add asynchronous behavior to be executed
after the current retry trigger in the companion publisher,
thus
delaying the resulting retry trigger with the additional
Mono
.
- doAfterRetryAsync(Function<Retry.RetrySignal, Mono<Void>>) - Method in class reactor.util.retry.RetrySpec
-
Add asynchronous behavior to be executed
after the current retry trigger in the companion publisher,
thus
delaying the resulting retry trigger with the additional
Mono
.
- doAfterSuccessOrError(BiConsumer<? super T, Throwable>) - Method in class reactor.core.publisher.Mono
-
- 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(Runnable) - Method in class reactor.core.publisher.Mono
-
Add behavior (side-effect) 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.
- doBeforeRetry(Consumer<Retry.RetrySignal>) - Method in class reactor.util.retry.RetryBackoffSpec
-
Add synchronous behavior to be executed before the retry trigger is emitted in
the companion publisher.
- doBeforeRetry(Consumer<Retry.RetrySignal>) - Method in class reactor.util.retry.RetrySpec
-
Add synchronous behavior to be executed before the retry trigger is emitted in
the companion publisher.
- doBeforeRetryAsync(Function<Retry.RetrySignal, Mono<Void>>) - Method in class reactor.util.retry.RetryBackoffSpec
-
Add asynchronous behavior to be executed
before the current retry trigger in the companion publisher,
thus
delaying the resulting retry trigger with the additional
Mono
.
- doBeforeRetryAsync(Function<Retry.RetrySignal, Mono<Void>>) - Method in class reactor.util.retry.RetrySpec
-
Add asynchronous behavior to be executed
before the current retry trigger in the companion publisher,
thus
delaying the resulting retry trigger with the additional
Mono
.
- doFinally(Consumer<SignalType>) - Method in class reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered
after the
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.
- doFirst(Runnable) - Method in class reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered
before the
Flux
is
subscribed to, which should be the first event after assembly time.
- doFirst(Runnable) - Method in class reactor.core.publisher.Mono
-
Add behavior (side-effect) triggered
before the
Mono
is
subscribed to, which should be the first event after assembly time.
- 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.
- doOnDiscard(Class<R>, Consumer<? super R>) - Method in class reactor.core.publisher.Flux
-
Potentially modify the behavior of the whole chain of operators upstream of this one to
conditionally clean up elements that get discarded by these operators.
- doOnDiscard(Class<R>, Consumer<? super R>) - Method in class reactor.core.publisher.Mono
-
Potentially modify the behavior of the whole chain of operators upstream of this one to
conditionally clean up elements that get discarded by these operators.
- 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 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'.
- 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
-
- doOnSubscribe(Consumer<? super Subscription>) - Method in class reactor.core.publisher.Mono
-
- 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 as soon as the
Mono
can be considered to have completed successfully.
- doOnSuccessOrError(BiConsumer<? super T, Throwable>) - Method in class reactor.core.publisher.Mono
-
- doOnTerminate(Runnable) - Method in class reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
terminates, either by
completing successfully or failing with an error.
- doOnTerminate(Runnable) - Method in class reactor.core.publisher.Mono
-
Add behavior triggered when the
Mono
terminates, either by completing with a value,
completing empty or failing 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
-
Deprecated.
- downstreamCount() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- downstreamCount() - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
Return the number of active
Subscriber
or -1 if untracked.
- downstreamCount() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
Return the number of active
Subscriber
or -1 if untracked.
- downstreamCount() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- downstreamCount() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- 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
-
- elapsed() - Method in class reactor.core.publisher.Flux
-
- elapsed(Scheduler) - Method in class reactor.core.publisher.Flux
-
- elapsed() - Method in class reactor.core.publisher.Mono
-
- elapsed(Scheduler) - Method in class reactor.core.publisher.Mono
-
- elapsed() - Method in interface reactor.core.publisher.Timed
-
Get the elapsed
Duration
since the previous onNext (or onSubscribe in
case this represents the first onNext).
- elapsedSinceSubscription() - Method in interface reactor.core.publisher.Timed
-
Get the elapsed
Duration
since the subscription (onSubscribe signal).
- elastic() - Static method in class reactor.core.scheduler.Schedulers
-
- element() - Method in interface reactor.core.Fuseable.QueueSubscription
-
- elementAt(int) - Method in class reactor.core.publisher.Flux
-
- elementAt(int, T) - Method in class reactor.core.publisher.Flux
-
Emit only the element at the given index position or fall back to a
default value if the sequence is shorter.
- EmissionException(Sinks.EmitResult) - Constructor for exception reactor.core.publisher.Sinks.EmissionException
-
- EmissionException(Throwable, Sinks.EmitResult) - Constructor for exception reactor.core.publisher.Sinks.EmissionException
-
- EmissionException(Sinks.EmitResult, String) - Constructor for exception reactor.core.publisher.Sinks.EmissionException
-
- emitComplete(Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Many
-
- emitEmpty(Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Empty
-
- emitError(Throwable, Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Empty
-
- emitError(Throwable, Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Many
-
- emitNext(T, Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Many
-
- emitNext(T, Sinks.EmitFailureHandler) - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- EmitterProcessor<T> - Class in reactor.core.publisher
-
- emitValue(T, Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.One
-
- empty() - Static method in class reactor.core.publisher.Flux
-
Create a
Flux
that completes without emitting any item.
- empty() - Static method in class reactor.core.publisher.Mono
-
Create a
Mono
that completes without emitting any item.
- empty() - Static method in class reactor.core.publisher.Sinks
-
A
Sinks.Empty
which exclusively produces one terminal signal: error or complete.
- empty() - Method in interface reactor.core.publisher.Sinks.RootSpec
-
A
Sinks.Empty
which exclusively produces one terminal signal: error or complete.
- empty() - Static method in class reactor.util.concurrent.Queues
-
A
Supplier
for an empty immutable
Queue
, to be used as a placeholder
in methods that require a Queue when one doesn't expect to store any data in said
Queue.
- empty() - Static method in interface reactor.util.context.Context
-
- emptySubscriber() - Static method in class reactor.core.publisher.Operators
-
A
Subscriber
that is expected to be used as a placeholder and
never actually be called.
- emptySubscription() - Static method in class reactor.core.publisher.Operators
-
A singleton enumeration that represents a no-op Subscription instance that
can be freely given out to clients.
- enableContextLossTracking() - Static method in class reactor.core.publisher.Hooks
-
- enableMetrics() - Static method in class reactor.core.scheduler.Schedulers
-
- enableOnDiscard(Context, Consumer<?>) - Static method in class reactor.core.publisher.Operators
-
- equals(Object) - Method in class reactor.util.function.Tuple2
-
- equals(Object) - Method in class reactor.util.function.Tuple3
-
- equals(Object) - Method in class reactor.util.function.Tuple4
-
- equals(Object) - Method in class reactor.util.function.Tuple5
-
- equals(Object) - Method in class reactor.util.function.Tuple6
-
- equals(Object) - Method in class reactor.util.function.Tuple7
-
- equals(Object) - Method in class reactor.util.function.Tuple8
-
- error(Throwable) - Static method in class reactor.core.publisher.Flux
-
Create a
Flux
that terminates with the specified error immediately after
being subscribed to.
- error(Supplier<? extends Throwable>) - Static method in class reactor.core.publisher.Flux
-
Create a
Flux
that terminates with an error immediately after being
subscribed to.
- error(Throwable, boolean) - Static method in class reactor.core.publisher.Flux
-
Create a
Flux
that terminates with the specified error, either immediately
after being subscribed to or after being first requested.
- error(Throwable) - Method in interface reactor.core.publisher.FluxSink
-
Fail the sequence, generating an
onError
signal.
- error(Throwable) - Static method in class reactor.core.publisher.Mono
-
Create a
Mono
that terminates with the specified error immediately after
being subscribed to.
- error(Supplier<? extends Throwable>) - Static method in class reactor.core.publisher.Mono
-
Create a
Mono
that terminates with an error immediately after being
subscribed to.
- error(Throwable) - Method in interface reactor.core.publisher.MonoSink
-
Terminate with the given exception
- error(Subscriber<?>, Throwable) - Static method in class reactor.core.publisher.Operators
-
Calls onSubscribe on the target Subscriber with the empty instance followed by a call to onError with the
supplied error.
- error(Throwable) - Static method in interface reactor.core.publisher.Signal
-
Creates and returns a Signal
of variety Type.FAILED
, which holds
the error.
- error(Throwable, Context) - Static method in interface reactor.core.publisher.Signal
-
Creates and returns a
Signal
of variety
Type.FAILED
, which holds
the error and the
Context
associated with the erroring source.
- error(Throwable) - Method in interface reactor.core.publisher.SynchronousSink
-
- ERROR - Static variable in class reactor.core.Scannable.Attr
-
a
Throwable
attribute which indicate an error state if the scanned
component keeps track of it.
- error(String) - Method in interface reactor.util.Logger
-
Log a message at the ERROR level.
- error(String, Object...) - Method in interface reactor.util.Logger
-
Log a message at the ERROR level according to the specified format
and arguments.
- error(String, Throwable) - Method in interface reactor.util.Logger
-
Log an exception (throwable) at the ERROR level with an
accompanying message.
- errorCallbackNotImplemented(Throwable) - Static method in class reactor.core.Exceptions
-
- errorFilter - Variable in class reactor.util.retry.RetryBackoffSpec
-
The configured
Predicate
to filter which exceptions to retry.
- errorFilter - Variable in class reactor.util.retry.RetrySpec
-
The configured
Predicate
to filter which exceptions to retry.
- Exceptions - Class in reactor.core
-
Global Reactor Core Exception handling and utils to operate on.
- expand(Function<? super T, ? extends Publisher<? extends T>>, int) - Method in class reactor.core.publisher.Flux
-
Recursively expand elements into a graph and emit all the resulting element using
a breadth-first traversal strategy.
- expand(Function<? super T, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
-
Recursively expand elements into a graph and emit all the resulting element using
a breadth-first traversal strategy.
- expand(Function<? super T, ? extends Publisher<? extends T>>, int) - Method in class reactor.core.publisher.Mono
-
Recursively expand elements into a graph and emit all the resulting element using
a breadth-first traversal strategy.
- expand(Function<? super T, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Mono
-
Recursively expand elements into a graph and emit all the resulting element using
a breadth-first traversal strategy.
- expandDeep(Function<? super T, ? extends Publisher<? extends T>>, int) - Method in class reactor.core.publisher.Flux
-
Recursively expand elements into a graph and emit all the resulting element,
in a depth-first traversal order.
- expandDeep(Function<? super T, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Flux
-
Recursively expand elements into a graph and emit all the resulting element,
in a depth-first traversal order.
- expandDeep(Function<? super T, ? extends Publisher<? extends T>>, int) - Method in class reactor.core.publisher.Mono
-
Recursively expand elements into a graph and emit all the resulting element,
in a depth-first traversal order.
- expandDeep(Function<? super T, ? extends Publisher<? extends T>>) - Method in class reactor.core.publisher.Mono
-
Recursively expand elements into a graph and emit all the resulting element,
in a depth-first traversal order.
- FAIL_FAST - Static variable in interface reactor.core.publisher.Sinks.EmitFailureHandler
-
A pre-made handler that will not instruct to retry any failure
and trigger the failure handling immediately.
- failure() - Method in interface reactor.util.retry.Retry.RetrySignal
-
- 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
- failWithRejected() - Static method in class reactor.core.Exceptions
-
- failWithRejected(Throwable) - Static method in class reactor.core.Exceptions
-
- failWithRejected(String) - Static method in class reactor.core.Exceptions
-
- failWithRejectedNotTimeCapable() - Static method in class reactor.core.Exceptions
-
- FALLBACK_PROPERTY - Static variable in class reactor.util.Loggers
-
The system property that determines which fallback implementation to use for loggers
when SLF4J isn't available.
- 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'.
- filter(Predicate<? super Throwable>) - Method in class reactor.util.retry.RetryBackoffSpec
-
Set the
Predicate
that will filter which errors can be retried.
- filter(Predicate<? super Throwable>) - Method in class reactor.util.retry.RetrySpec
-
Set the
Predicate
that will filter which errors can be retried.
- 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(Publisher<? extends I>...) - Static method in class reactor.core.publisher.Flux
-
- first(Iterable<? extends Publisher<? extends I>>) - Static method in class reactor.core.publisher.Flux
-
- first(Mono<? extends T>...) - Static method in class reactor.core.publisher.Mono
-
- first(Iterable<? extends Mono<? extends T>>) - Static method in class reactor.core.publisher.Mono
-
- firstWithSignal(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.
- firstWithSignal(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.
- firstWithSignal(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.
- firstWithSignal(Iterable<? extends 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.
- firstWithValue(Iterable<? extends Publisher<? extends I>>) - Static method in class reactor.core.publisher.Flux
-
Pick the first
Publisher
to emit any value and replay all values
from that
Publisher
, effectively behaving like the source that first
emits an
onNext
.
- firstWithValue(Publisher<? extends I>, Publisher<? extends I>...) - Static method in class reactor.core.publisher.Flux
-
Pick the first
Publisher
to emit any value and replay all values
from that
Publisher
, effectively behaving like the source that first
emits an
onNext
.
- firstWithValue(Iterable<? extends Mono<? extends T>>) - Static method in class reactor.core.publisher.Mono
-
Pick the first
Mono
source to emit any value and replay that signal,
effectively behaving like the source that first emits an
onNext
.
- firstWithValue(Mono<? extends T>, Mono<? extends T>...) - Static method in class reactor.core.publisher.Mono
-
Pick the first
Mono
source to emit any value and replay that signal,
effectively behaving like the source that first emits an
onNext
.
- fixedDelay(long, Duration) - Static method in class reactor.util.retry.Retry
-
A
RetryBackoffSpec
preconfigured for fixed delays (min backoff equals max backoff, no jitter), given a maximum number of retry attempts
and the fixed
Duration
for the backoff.
- 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 signals 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
-
- FluxOperator<I,O> - Class in reactor.core.publisher
-
- FluxOperator(Flux<? extends I>) - Constructor for class reactor.core.publisher.FluxOperator
-
- FluxProcessor<IN,OUT> - Class in reactor.core.publisher
-
- FluxProcessor() - Constructor for class reactor.core.publisher.FluxProcessor
-
Deprecated.
- 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.
- 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
-
- from(Function<Flux<Retry.RetrySignal>, ? extends Publisher<?>>) - Static method in class reactor.util.retry.Retry
-
A wrapper around
Function
to provide
Retry
by using lambda expressions.
- 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
-
- fromCompletionStage(Supplier<? extends 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 cancel 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, String) - Static method in class reactor.core.scheduler.Schedulers
-
- fromFuture(CompletableFuture<? extends T>) - Static method in class reactor.core.publisher.Mono
-
- fromFuture(Supplier<? extends 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
.
- fromStream(Supplier<Stream<? extends T>>) - Static method in class reactor.core.publisher.Flux
-
Create a
Flux
that emits the items contained in a
Stream
created by
the provided
Supplier
for each subscription.
- 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,
otherwise fail 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.
- 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 immediately instead of scheduling them.
- indefinitely() - Static method in class reactor.util.retry.Retry
-
A
RetrySpec
preconfigured for the most simplistic retry strategy: retry immediately and indefinitely
(similar to
Flux.retry()
).
- index() - Method in class reactor.core.publisher.Flux
-
Keep information about the order in which source values were received by
indexing them with a 0-based incrementing long, returning a
Flux
of
Tuple2<(index, value)>
.
- index(BiFunction<? super Long, ? super T, ? extends I>) - Method in class reactor.core.publisher.Flux
-
Keep information about the order in which source values were received by
indexing them internally with a 0-based incrementing long then combining this
information with the source value into a
I
using the provided
BiFunction
,
returning a
Flux<I>
.
- 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
-
Deprecated.
- inners() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- inners() - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
- inners() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
- inners() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- inners() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- inners() - Method in interface reactor.core.Scannable
-
Return a
Stream
of referenced inners (flatmap, multicast etc)
- 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
.
- 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
-
Deprecated.
- isCancelled() - Method in interface reactor.core.publisher.FluxSink
-
Returns true if the downstream cancelled the sequence.
- isCancelled() - Method in class reactor.core.publisher.MonoProcessor
-
- isCancelled() - Method in class reactor.core.publisher.Operators.DeferredSubscription
-
- isCancelled() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
Returns true if this Subscription has been cancelled.
- isComplete(Object) - Static method in interface 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.Composite
-
Indicates if the container has already been disposed.
- 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.EmitterProcessor
-
Deprecated.
- isDisposed() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
- isDisposed() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- isDisposed() - Method in class reactor.core.scheduler.Schedulers.Snapshot
-
- isEmpty() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- isEmpty() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- isEmpty() - Method in interface reactor.util.context.ContextView
-
Return true if the
Context
is empty.
- isError() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
Indicates whether this MonoProcessor
has been completed with an error.
- isError(Object) - Static method in interface 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?
- isFailure() - Method in enum reactor.core.publisher.Sinks.EmitResult
-
Represents a failure to emit a signal.
- isIdentityProcessor() - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- isIdentityProcessor() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- isIdentityProcessor() - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
Return true if FluxProcessor<T, T>
- isIdentityProcessor() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- isIdentityProcessor() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- isInfoEnabled() - Method in interface reactor.util.Logger
-
Is the logger instance enabled for the INFO level?
- isInNonBlockingThread() - Static method in class reactor.core.scheduler.Schedulers
-
Check if calling a Reactor blocking API in the current
Thread
is forbidden
or not, by checking if the thread implements
NonBlocking
(in which case it is
forbidden and this method returns
true
).
- isInstrumentationAvailable() - Static method in class reactor.util.Metrics
-
Check if the current runtime supports metrics / instrumentation, by
verifying if Micrometer is on the classpath.
- isMultiple(Throwable) - Static method in class reactor.core.Exceptions
-
- isNonBlockingThread(Thread) - Static method in class reactor.core.scheduler.Schedulers
-
Check if calling a Reactor blocking API in the given
Thread
is forbidden
or not, by checking if the thread implements
NonBlocking
(in which case it is
forbidden and this method returns
true
).
- isOnComplete() - Method in interface reactor.core.publisher.Signal
-
Indicates whether this signal represents an onComplete
event.
- isOnError() - Method in interface reactor.core.publisher.Signal
-
Indicates whether this signal represents an onError
event.
- isOnNext() - Method in interface reactor.core.publisher.Signal
-
Indicates whether this signal represents an onNext
event.
- isOnSubscribe() - Method in interface 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.Queues
-
- isRetryExhausted(Throwable) - Static method in class reactor.core.Exceptions
-
Check a
Throwable
to see if it indicates too many retry attempts have failed.
- isScanAvailable() - Method in interface reactor.core.Scannable
-
- isSerialized() - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
- isSuccess() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
Indicates whether this MonoProcessor
has been successfully completed a value.
- isSuccess() - Method in enum reactor.core.publisher.Sinks.EmitResult
-
Represents a successful emission of a signal.
- isTerminated() - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- isTerminated() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- isTerminated() - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
Has this upstream finished or "completed" / "failed" ?
- isTerminated() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
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
-
Deprecated.
- isTerminated() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- isTraceback(Throwable) - Static method in class reactor.core.Exceptions
-
Check a
Throwable
to see if it is a traceback, as created by the checkpoint operator or debug utilities.
- isTraceEnabled() - Method in interface reactor.util.Logger
-
Is the logger instance enabled for the TRACE level?
- isTransientErrors - Variable in class reactor.util.retry.RetryBackoffSpec
-
The configured transient error handling flag.
- isTransientErrors - Variable in class reactor.util.retry.RetrySpec
-
The configured transient error handling flag.
- 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(Object, Object) - Static method in interface reactor.util.context.Context
-
Create a
Context
pre-initialized with one key-value pair.
- of(Object, Object, Object, Object) - Static method in interface reactor.util.context.Context
-
Create a
Context
pre-initialized with two key-value pairs.
- of(Object, Object, Object, Object, Object, Object) - Static method in interface reactor.util.context.Context
-
Create a
Context
pre-initialized with three key-value pairs.
- of(Object, Object, Object, Object, Object, Object, Object, Object) - Static method in interface reactor.util.context.Context
-
Create a
Context
pre-initialized with four key-value pairs.
- of(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in interface reactor.util.context.Context
-
Create a
Context
pre-initialized with five key-value pairs.
- of(Map<?, ?>) - Static method in interface reactor.util.context.Context
-
- of(ContextView) - Static method in interface reactor.util.context.Context
-
- 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 up to
maxSize
elements when 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 up to
maxSize
elements when 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.
- onBackpressureBuffer(Duration, 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, within a
maxSize
limit and for a maximum
Duration
of
ttl
(as measured on the
parallel Scheduler
).
- onBackpressureBuffer(Duration, int, Consumer<? super T>, Scheduler) - 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 and for a maximum
Duration
of
ttl
(as measured on the provided
Scheduler
).
- onBackpressureBuffer() - Method in interface reactor.core.publisher.Sinks.MulticastSpec
-
- onBackpressureBuffer(int) - Method in interface reactor.core.publisher.Sinks.MulticastSpec
-
- onBackpressureBuffer(int, boolean) - Method in interface reactor.core.publisher.Sinks.MulticastSpec
-
- onBackpressureBuffer() - Method in interface reactor.core.publisher.Sinks.UnicastSpec
-
A
Sinks.Many
with the following characteristics:
Unicast: contrary to most other
Sinks.Many
, the
Flux
view rejects
subscribers
past the first one.
Backpressure : this sink honors downstream demand of its single
Subscriber
.
Replaying: non-applicable, since only one
Subscriber
can register.
Without
Subscriber
: all elements pushed to this sink are remembered and will
be replayed once the
Subscriber
subscribes.
- onBackpressureBuffer(Queue<T>) - Method in interface reactor.core.publisher.Sinks.UnicastSpec
-
A
Sinks.Many
with the following characteristics:
Unicast: contrary to most other
Sinks.Many
, the
Flux
view rejects
subscribers
past the first one.
Backpressure : this sink honors downstream demand of its single
Subscriber
.
Replaying: non-applicable, since only one
Subscriber
can register.
Without
Subscriber
: depending on the queue, all elements pushed to this sink are remembered and will
be replayed once the
Subscriber
subscribes.
- onBackpressureBuffer(Queue<T>, Disposable) - Method in interface reactor.core.publisher.Sinks.UnicastSpec
-
A
Sinks.Many
with the following characteristics:
Unicast: contrary to most other
Sinks.Many
, the
Flux
view rejects
subscribers
past the first one.
Backpressure : this sink honors downstream demand of its single
Subscriber
.
Replaying: non-applicable, since only one
Subscriber
can register.
Without
Subscriber
: depending on the queue, all elements pushed to this sink are remembered and will
be replayed once the
Subscriber
subscribes.
- 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
-
- onBackpressureError() - Method in interface reactor.core.publisher.Sinks.UnicastSpec
-
- 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
-
- onCancel(Disposable) - Method in interface reactor.core.publisher.MonoSink
-
- onComplete() - Method in class reactor.core.publisher.BaseSubscriber
-
- onComplete() - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- onComplete() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- onComplete() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- onComplete() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- onComplete() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- onDiscard(T, Context) - Static method in class reactor.core.publisher.Operators
-
Invoke a (local or global) hook that processes elements that get discarded.
- onDiscardMultiple(Stream<?>, Context) - Static method in class reactor.core.publisher.Operators
-
Invoke a (local or global) hook that processes elements that get discarded en masse.
- onDiscardMultiple(Collection<?>, Context) - Static method in class reactor.core.publisher.Operators
-
Invoke a (local or global) hook that processes elements that get discarded en masse.
- onDiscardMultiple(Iterator<?>, boolean, Context) - Static method in class reactor.core.publisher.Operators
-
Invoke a (local or global) hook that processes elements that remains in an
Iterator
.
- onDiscardQueueWithClear(Queue<T>, Context, Function<T, Stream<?>>) - Static method in class reactor.core.publisher.Operators
-
Invoke a (local or global) hook that processes elements that get discarded
en masse after having been enqueued, due to cancellation or error.
- onDispose(Disposable) - Method in interface reactor.core.publisher.FluxSink
-
Attach a
Disposable
as a callback for when this
FluxSink
is effectively
disposed, that is it cannot be used anymore.
- onDispose(Disposable) - Method in interface reactor.core.publisher.MonoSink
-
Attach a
Disposable
as a callback for when this
MonoSink
is effectively
disposed, that is it cannot be used anymore.
- one() - Static method in class reactor.core.publisher.Sinks
-
A
Sinks.One
that works like a conceptual promise: it can be completed
with or without a value at any time, but only once.
- one() - Method in interface reactor.core.publisher.Sinks.RootSpec
-
A
Sinks.One
that works like a conceptual promise: it can be completed
with or without a value at any time, but only once.
- one() - Static method in class reactor.util.concurrent.Queues
-
- onEachOperator(Function<? super Publisher<Object>, ? extends Publisher<Object>>) - Static method in class reactor.core.publisher.Hooks
-
- onEachOperator(String, Function<? super Publisher<Object>, ? extends Publisher<Object>>) - Static method in class reactor.core.publisher.Hooks
-
Add or replace a named
Publisher
operator interceptor for each operator created
(
Flux
or
Mono
).
- onEmitFailure(SignalType, Sinks.EmitResult) - Method in interface reactor.core.publisher.Sinks.EmitFailureHandler
-
Decide whether the emission should be retried, depending on the provided
Sinks.EmitResult
and the type of operation that was attempted (represented as a
SignalType
).
- onError(Throwable) - Method in class reactor.core.publisher.BaseSubscriber
-
- onError(Throwable) - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- onError(Throwable) - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- onError(Throwable) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- onError(Throwable) - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- onError(Throwable) - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- onErrorContinue(BiConsumer<Throwable, Object>) - Method in class reactor.core.publisher.Flux
-
Let compatible operators upstream recover from errors by dropping the
incriminating element from the sequence and continuing with subsequent elements.
- onErrorContinue(Class<E>, BiConsumer<Throwable, Object>) - Method in class reactor.core.publisher.Flux
-
Let compatible operators upstream recover from errors by dropping the
incriminating element from the sequence and continuing with subsequent elements.
- onErrorContinue(Predicate<E>, BiConsumer<Throwable, Object>) - Method in class reactor.core.publisher.Flux
-
Let compatible operators upstream recover from errors by dropping the
incriminating element from the sequence and continuing with subsequent elements.
- onErrorContinue(BiConsumer<Throwable, Object>) - Method in class reactor.core.publisher.Mono
-
Let compatible operators upstream recover from errors by dropping the
incriminating element from the sequence and continuing with subsequent elements.
- onErrorContinue(Class<E>, BiConsumer<Throwable, Object>) - Method in class reactor.core.publisher.Mono
-
Let compatible operators upstream recover from errors by dropping the
incriminating element from the sequence and continuing with subsequent elements.
- onErrorContinue(Predicate<E>, BiConsumer<Throwable, Object>) - Method in class reactor.core.publisher.Mono
-
Let compatible operators upstream recover from errors by dropping the
incriminating element from the sequence and continuing with subsequent elements.
- 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, Context) - 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(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.
- 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.
- 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
.
- onErrorStop() - Method in class reactor.core.publisher.Flux
-
- onErrorStop() - Method in class reactor.core.publisher.Mono
-
- onHandleError(BiConsumer<Thread, ? super Throwable>) - Static method in class reactor.core.scheduler.Schedulers
-
- onLastAssembly(CorePublisher<T>) - Static method in class reactor.core.publisher.Operators
-
- onLastOperator(Function<? super Publisher<Object>, ? extends Publisher<Object>>) - Static method in class reactor.core.publisher.Hooks
-
Add a
Publisher
operator interceptor for the last operator created
in every flow (
Flux
or
Mono
).
- onLastOperator(String, Function<? super Publisher<Object>, ? extends Publisher<Object>>) - Static method in class reactor.core.publisher.Hooks
-
Add or replace a named
Publisher
operator interceptor for the last operator created
in every flow (
Flux
or
Mono
).
- onNext(T) - Method in class reactor.core.publisher.BaseSubscriber
-
- onNext(T) - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- onNext(T) - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- onNext(I) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- onNext(T) - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- onNext(T) - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- onNextDropped(Consumer<Object>) - Static method in class reactor.core.publisher.Hooks
-
Override global data dropped strategy which by default logs at DEBUG level.
- onNextDropped(T, Context) - Static method in class reactor.core.publisher.Operators
-
An unexpected event is about to be dropped.
- onNextDroppedFail() - Static method in class reactor.core.publisher.Hooks
-
- onNextError(BiFunction<? super Throwable, Object, ? extends Throwable>) - Static method in class reactor.core.publisher.Hooks
-
Set the custom global error mode hook for operators that support resuming
during an error in their
Subscriber.onNext(Object)
.
- onNextError(T, Throwable, Context, Subscription) - Static method in class reactor.core.publisher.Operators
-
Find the
OnNextFailureStrategy
to apply to the calling operator (which could be a local
error mode defined in the
Context
) and apply it.
- onNextError(T, Throwable, Context) - Static method in class reactor.core.publisher.Operators
-
Find the
OnNextFailureStrategy
to apply to the calling async operator (which could be
a local error mode defined in the
Context
) and apply it.
- onNextErrorFunction(Context) - Static method in class reactor.core.publisher.Operators
-
- onNextInnerError(Throwable, Context, Subscription) - Static method in class reactor.core.publisher.Operators
-
Find the
OnNextFailureStrategy
to apply to the calling operator (which could be a local
error mode defined in the
Context
) and apply it.
- onNextPollError(T, Throwable, Context) - Static method in class reactor.core.publisher.Operators
-
Find the
OnNextFailureStrategy
to apply to the calling async operator (which could be
a local error mode defined in the
Context
) and apply it.
- onOperatorDebug() - Static method in class reactor.core.publisher.Hooks
-
Enable operator stack recorder that captures a declaration stack whenever an
operator is instantiated.
- onOperatorError(BiFunction<? super Throwable, Object, ? extends Throwable>) - Static method in class reactor.core.publisher.Hooks
-
Add a custom error mapping, overriding the default one.
- onOperatorError(String, BiFunction<? super Throwable, Object, ? extends Throwable>) - Static method in class reactor.core.publisher.Hooks
-
Add or replace a named custom error mapping, overriding the default one.
- onOperatorError(Throwable, Context) - Static method in class reactor.core.publisher.Operators
-
Map an "operator" error.
- onOperatorError(Subscription, Throwable, Context) - Static method in class reactor.core.publisher.Operators
-
Map an "operator" error given an operator parent
Subscription
.
- onOperatorError(Subscription, Throwable, Object, Context) - Static method in class reactor.core.publisher.Operators
-
Map an "operator" error given an operator parent
Subscription
.
- onRejectedExecution(Throwable, Context) - Static method in class reactor.core.publisher.Operators
-
- onRejectedExecution(Throwable, Subscription, Throwable, Object, Context) - 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
-
- onRetryExhaustedThrow(BiFunction<RetryBackoffSpec, Retry.RetrySignal, Throwable>) - Method in class reactor.util.retry.RetryBackoffSpec
-
Set the generator for the
Exception
to be propagated when the maximum amount of retries
is exhausted.
- onRetryExhaustedThrow(BiFunction<RetrySpec, Retry.RetrySignal, Throwable>) - Method in class reactor.util.retry.RetrySpec
-
Set the generator for the
Exception
to be propagated when the maximum amount of retries
is exhausted.
- onSchedule(Runnable) - Static method in class reactor.core.scheduler.Schedulers
-
- onScheduleHook(String, Function<Runnable, Runnable>) - Static method in class reactor.core.scheduler.Schedulers
-
- onSubscribe(Subscription) - Method in interface reactor.core.CoreSubscriber
-
- onSubscribe(Subscription) - Method in class reactor.core.publisher.BaseSubscriber
-
- onSubscribe(Subscription) - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- onSubscribe(Subscription) - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- onSubscribe(Subscription) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- onSubscribe(Subscription) - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- onSubscribe(Subscription) - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- onTerminateDetach() - Method in class reactor.core.publisher.Flux
-
- onTerminateDetach() - Method in class reactor.core.publisher.Mono
-
- OPERATOR_NAME_UNRELATED_WORDS_PATTERN - Static variable in interface reactor.core.Scannable
-
The pattern for matching words unrelated to operator name.
- Operators - Class in reactor.core.publisher
-
A 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.
- or(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.
- or(Mono<? extends T>) - Method in class reactor.core.publisher.Mono
-
Emit the first available signal from this mono or the other mono.
- ordered(Comparator<? super T>) - Method in class reactor.core.publisher.ParallelFlux
-
Merges the values from each 'rail', but choose which one to merge by way of a
provided
Comparator
, picking the smallest of all rails.
- ordered(Comparator<? super T>, int) - Method in class reactor.core.publisher.ParallelFlux
-
Merges the values from each 'rail', but choose which one to merge by way of a
provided
Comparator
, picking the smallest of all rails.
- orThrow() - Method in enum reactor.core.publisher.Sinks.EmitResult
-
- orThrowWithCause(Throwable) - Method in enum reactor.core.publisher.Sinks.EmitResult
-
- range(int, int) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
that will only emit a sequence of
count
incrementing integers,
starting from
start
.
- 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.annotation - package reactor.util.annotation
-
- reactor.util.concurrent - package reactor.util.concurrent
-
Queue
suppliers and utilities
Used for operational serialization (serializing threads) or buffering (asynchronous boundary).
- reactor.util.context - package reactor.util.context
-
Miscellaneous utility classes, such as loggers, tuples or queue suppliers and implementations.
- reactor.util.function - package reactor.util.function
-
Tuples
provide a type-safe way to specify multiple parameters.
- reactor.util.retry - package reactor.util.retry
-
- readOnly() - Method in interface reactor.util.context.Context
-
Switch to the
ContextView
interface, which only allows reading from the
context.
- reduce(BiFunction<T, T, T>) - Method in class reactor.core.publisher.Flux
-
Reduce the values from this
Flux
sequence into a 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 a 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 a 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.
- refCount(int, Duration) - Method in class reactor.core.publisher.ConnectableFlux
-
Connects to the upstream source when the given number of
Subscriber
subscribes.
- refCount(int, Duration, Scheduler) - Method in class reactor.core.publisher.ConnectableFlux
-
Connects to the upstream source when the given number of
Subscriber
subscribes.
- remove(Disposable) - Method in interface reactor.core.Disposable.Composite
-
Delete the
Disposable
from this container, without disposing it.
- remove() - Method in interface reactor.core.Fuseable.QueueSubscription
-
- remove(Object) - Method in interface reactor.core.Fuseable.QueueSubscription
-
- remove(SinkManyBestEffort.DirectInner<T>) - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- removeAll(Collection<?>) - Method in interface reactor.core.Fuseable.QueueSubscription
-
- removeExecutorServiceDecorator(String) - Static method in class reactor.core.scheduler.Schedulers
-
- removeQueueWrapper(String) - Static method in class reactor.core.publisher.Hooks
-
Removes existing
Queue
wrapper by key.
- removeQueueWrappers() - Static method in class reactor.core.publisher.Hooks
-
Remove all queue wrappers.
- 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(Disposable) - Method in interface reactor.core.Disposable.Swap
-
Atomically set the next
Disposable
on this container but don't dispose the previous
one (if any).
- 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
.
- replay() - Method in interface reactor.core.publisher.Sinks.ManySpec
-
Help building
Sinks.Many
that will broadcast signals to multiple
Subscriber
with the ability to retain
and replay all or an arbitrary number of elements.
- ReplayProcessor<T> - Class in reactor.core.publisher
-
- 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
-
- reportThrowInSubscribe(CoreSubscriber<?>, Throwable) - 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
-
Deprecated.
- REQUESTED_FROM_DOWNSTREAM - Static variable in class reactor.core.Scannable.Attr
-
A
Long
attribute exposing the current pending demand of a downstream
component.
- 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
-
Deprecated.
- requestUnbounded() - Method in class reactor.core.publisher.BaseSubscriber
-
- resetFactory() - Static method in class reactor.core.scheduler.Schedulers
-
- resetFrom(Schedulers.Snapshot) - Static method in class reactor.core.scheduler.Schedulers
-
Replace the current Factory and shared Schedulers with the ones saved in a
previously
captured
snapshot.
- resetLoggerFactory() - Static method in class reactor.util.Loggers
-
- resetOnEachOperator(String) - Static method in class reactor.core.publisher.Hooks
-
Remove the sub-hook with key key
from the onEachOperator hook.
- resetOnEachOperator() - Static method in class reactor.core.publisher.Hooks
-
Reset global "assembly" hook tracking
- 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
-
- resetOnLastOperator(String) - Static method in class reactor.core.publisher.Hooks
-
Remove the sub-hook with key key
from the onLastOperator hook.
- resetOnLastOperator() - Static method in class reactor.core.publisher.Hooks
-
Reset global "subscriber" hook tracking
- resetOnNextDropped() - Static method in class reactor.core.publisher.Hooks
-
- resetOnNextError() - Static method in class reactor.core.publisher.Hooks
-
Reset global onNext error handling strategy to terminating the sequence with
an onError and cancelling upstream (OnNextFailureStrategy.STOP
).
- resetOnOperatorDebug() - Static method in class reactor.core.publisher.Hooks
-
Reset global operator debug.
- resetOnOperatorError(String) - Static method in class reactor.core.publisher.Hooks
-
Remove the sub-hook with key key
from the onOperatorError hook.
- resetOnOperatorError() - Static method in class reactor.core.publisher.Hooks
-
Reset global operator error mapping to the default behavior.
- resetOnScheduleHook(String) - Static method in class reactor.core.scheduler.Schedulers
-
- resetOnScheduleHooks() - Static method in class reactor.core.scheduler.Schedulers
-
- 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() - 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 - Class in reactor.util.retry
-
- Retry() - Constructor for class reactor.util.retry.Retry
-
- Retry(ContextView) - Constructor for class reactor.util.retry.Retry
-
- Retry.RetrySignal - Interface in reactor.util.retry
-
- RetryBackoffSpec - Class in reactor.util.retry
-
A
Retry
strategy based on exponential backoffs, with configurable features.
- retryContext - Variable in class reactor.util.retry.Retry
-
- retryContext() - Method in class reactor.util.retry.Retry
-
Return the user provided context that was set at construction time.
- retryContextView() - Method in interface reactor.util.retry.Retry.RetrySignal
-
Return a read-only view of the user provided context, which may be used to store
objects to be reset/rolled-back or otherwise mutated before or after a retry.
- retryExhausted(String, Throwable) - Static method in class reactor.core.Exceptions
-
- RetrySpec - Class in reactor.util.retry
-
A simple count-based
Retry
strategy with configurable features.
- retryWhen(Retry) - Method in class reactor.core.publisher.Flux
-
Retries this
Flux
in response to signals emitted by a companion
Publisher
.
- retryWhen(Retry) - Method in class reactor.core.publisher.Mono
-
Retries this
Mono
in response to signals emitted by a companion
Publisher
.
- RUN_ON - Static variable in class reactor.core.Scannable.Attr
-
- RUN_STYLE - Static variable in class reactor.core.Scannable.Attr
-
An
Scannable.Attr.RunStyle
enum attribute indicating whether or not an operator continues to operate on the same thread.
- runOn(Scheduler) - Method in class reactor.core.publisher.ParallelFlux
-
Specifies where each 'rail' will observe its incoming values with possible
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 possible
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(CoreSubscriber<? 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.
- scalarSubscription(CoreSubscriber<? super T>, T, String) - 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(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<T>) - Method in interface reactor.core.Scannable
-
Introspect a component's specific state
attribute
, returning an
associated value specific to that component, or the default value associated with
the key, or null if the attribute doesn't make sense for that particular component
and has no sensible default.
- 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<T> - Class in reactor.core
-
Base class for
Scannable
attributes, which all can define a meaningful
default.
- Scannable.Attr.RunStyle - Enum in reactor.core
-
An
Enum
enumerating the different styles an operator can run : their
Enum.ordinal()
reflects the level of confidence
in their running mode
- scanOrDefault(Scannable.Attr<T>, T) - Method in interface reactor.core.Scannable
-
Introspect a component's specific state
attribute
.
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.FluxOperator
-
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.MonoOperator
-
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.Operators.DeferredSubscription
-
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- scanUnsafe(Scannable.Attr) - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- scanUnsafe(Scannable.Attr) - Method in interface reactor.core.Scannable
-
This method is used internally by components to define their key-value mappings
in a single place.
- 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(Scheduler) - Method in class reactor.util.retry.RetryBackoffSpec
-
Set a
Scheduler
on which to execute the delays computed by the exponential backoff
strategy.
- Scheduler.Worker - Interface in reactor.core.scheduler
-
A worker representing an asynchronous boundary that executes tasks.
- 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
- Schedulers.Snapshot - Class in reactor.core.scheduler
-
- 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
-
Deprecated.
- serialize(CoreSubscriber<? super T>) - Static method in class reactor.core.publisher.Operators
-
Safely gate a
Subscriber
by making sure onNext signals are delivered
sequentially (serialized).
- serializeAlways() - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
Returns serialization strategy.
- 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.
- setExecutorServiceDecorator(String, BiFunction<Scheduler, ScheduledExecutorService, ScheduledExecutorService>) - Static method in class reactor.core.scheduler.Schedulers
-
- setFactory(Schedulers.Factory) - Static method in class reactor.core.scheduler.Schedulers
-
- setFactoryWithSnapshot(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() - Method in class reactor.core.publisher.Mono
-
- shareNext() - Method in class reactor.core.publisher.Flux
-
Prepare a
Mono
which shares this
Flux
sequence and dispatches the
first observed item to subscribers.
- shutdownNow() - Static method in class reactor.core.scheduler.Schedulers
-
Clear any cached
Scheduler
and call dispose on them.
- Signal<T> - Interface in reactor.core.publisher
-
A domain representation of a Reactive Stream signal.
- SignalType - Enum in reactor.core.publisher
-
Reactive Stream signal types
- single() - Static method in class reactor.core.Disposables
-
- 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() - Method in class reactor.core.publisher.Mono
-
- 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
-
- SinkOneSerialized<T> - Class in reactor.core.publisher
-
- SinkOneSerialized(Sinks.One<T>, ContextHolder) - Constructor for class reactor.core.publisher.SinkOneSerialized
-
- Sinks - Class in reactor.core.publisher
-
Sinks are constructs through which Reactive Streams signals can be programmatically pushed, with
Flux
or
Mono
semantics.
- Sinks.EmissionException - Exception in reactor.core.publisher
-
- Sinks.EmitFailureHandler - Interface in reactor.core.publisher
-
A handler supporting the emit API (eg.
- Sinks.EmitResult - Enum in reactor.core.publisher
-
Represents the immediate result of an emit attempt (eg.
- Sinks.Empty<T> - Interface in reactor.core.publisher
-
A base interface for standalone
Sinks
with complete-or-fail semantics.
- Sinks.Many<T> - Interface in reactor.core.publisher
-
A base interface for standalone
Sinks
with
Flux
semantics.
- Sinks.ManySpec - Interface in reactor.core.publisher
-
Provides
Sinks.Many
specs for sinks which can emit multiple elements
- Sinks.MulticastReplaySpec - Interface in reactor.core.publisher
-
Provides multicast with history/replay capacity : 1 sink, N
Subscriber
- Sinks.MulticastSpec - Interface in reactor.core.publisher
-
- Sinks.One<T> - Interface in reactor.core.publisher
-
A base interface for standalone
Sinks
with
Mono
semantics.
- Sinks.RootSpec - Interface in reactor.core.publisher
-
- Sinks.UnicastSpec - Interface in reactor.core.publisher
-
- size() - Method in interface reactor.core.Disposable.Composite
-
Returns the number of currently held Disposables.
- size() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- size() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- size() - Method in interface reactor.util.context.ContextView
-
Return the size of this
Context
, the number of immutable key/value pairs stored inside it.
- 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.
- small() - Static method in class reactor.util.concurrent.Queues
-
- SMALL_BUFFER_SIZE - Static variable in class reactor.util.concurrent.Queues
-
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.FluxOperator
-
- source - Variable in class reactor.core.publisher.MonoOperator
-
- 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
-
- stepName() - Method in interface reactor.core.Scannable
-
- steps() - Method in interface reactor.core.Scannable
-
List the step names in the chain of
Scannable
(including the current element),
in their assembly order.
- stream() - Method in interface reactor.util.context.ContextView
-
Stream key/value pairs from this
Context
- subOrZero(long, long) - Static method in class reactor.core.publisher.Operators
-
Cap a subtraction to 0
- subscribe(CoreSubscriber<? super T>) - Method in interface reactor.core.CorePublisher
-
- subscribe(CoreSubscriber<? super T>) - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- subscribe(CoreSubscriber<? super T>) - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- 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<? super T>, Consumer<? super Throwable>, Runnable, Context) - 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(Subscriber<? super T>) - Method in class reactor.core.publisher.Flux
-
- subscribe(CoreSubscriber<? super T>) - Method in class reactor.core.publisher.Flux
-
- subscribe() - Method in class reactor.core.publisher.Mono
-
Subscribe to this
Mono
and request unbounded demand.
- subscribe(Consumer<? super T>) - Method in class reactor.core.publisher.Mono
-
Subscribe a
Consumer
to this
Mono
that will consume all the
sequence.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class reactor.core.publisher.Mono
-
Subscribe 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(Consumer<? super T>, Consumer<? super Throwable>, Runnable, Context) - 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(Subscriber<? super T>) - Method in class reactor.core.publisher.Mono
-
- subscribe(CoreSubscriber<? super T>) - Method in class reactor.core.publisher.Mono
-
- subscribe(CoreSubscriber<? 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(CoreSubscriber<? super T>) - Method in class reactor.core.publisher.ParallelFlux
-
- 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(Consumer<? super T>, Consumer<? super Throwable>, Runnable, Context) - Method in class reactor.core.publisher.ParallelFlux
-
Subscribes to this
ParallelFlux
by providing an onNext, onError and
onComplete callback as well as an initial
Context
, then trigger the execution chain for all
'rails'.
- subscribe(Subscriber<? super T>) - Method in class reactor.core.publisher.ParallelFlux
-
- subscribe(CoreSubscriber<? super T>) - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- subscribe(Subscription) - Static method in interface reactor.core.publisher.Signal
-
Creates and returns a Signal
of variety Type.ON_SUBSCRIBE
.
- subscribe(Subscription, Context) - Static method in interface reactor.core.publisher.Signal
-
Creates and returns a
Signal
of variety
Type.ON_SUBSCRIBE
, that
holds the
Context
associated with the subscribed source.
- subscribe(CoreSubscriber<? super T>) - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- subscribeOn(Scheduler) - Method in class reactor.core.publisher.Flux
-
- subscribeOn(Scheduler, boolean) - Method in class reactor.core.publisher.Flux
-
- subscribeOn(Scheduler) - Method in class reactor.core.publisher.Mono
-
- subscriberContext(Context) - Method in class reactor.core.publisher.Flux
-
- subscriberContext(Function<Context, Context>) - Method in class reactor.core.publisher.Flux
-
- subscriberContext() - Static method in class reactor.core.publisher.Mono
-
- subscriberContext(Context) - Method in class reactor.core.publisher.Mono
-
- subscriberContext(Function<Context, Context>) - 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 this
Mono
with the given value.
- swap() - Static method in class reactor.core.Disposables
-
Create a new empty
Disposable.Swap
with atomic guarantees on all mutative
operations.
- 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
-
- switchOnFirst(BiFunction<Signal<? extends T>, Flux<T>, Publisher<? extends V>>) - Method in class reactor.core.publisher.Flux
-
Transform the current
Flux
once it emits its first element, making a
conditional transformation possible.
- switchOnFirst(BiFunction<Signal<? extends T>, Flux<T>, Publisher<? extends V>>, boolean) - Method in class reactor.core.publisher.Flux
-
Transform the current
Flux
once it emits its first element, making a
conditional transformation possible.
- 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
-
- 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 produce synchronously "one signal" to an underlying
Subscriber
.
- tag(String, String) - Method in class reactor.core.publisher.Flux
-
Tag this flux with a key/value pair.
- tag(String, String) - Method in class reactor.core.publisher.Mono
-
Tag this mono with a key/value pair.
- tag(String, String) - Method in class reactor.core.publisher.ParallelFlux
-
Tag this ParallelFlux with a key/value pair.
- TAGS - Static variable in class reactor.core.Scannable.Attr
-
A
Stream
of
Tuple2
representing key/value
pairs for tagged components.
- tags() - Method in interface reactor.core.Scannable
-
- 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
.
- take(Duration) - Method in class reactor.core.publisher.Mono
-
Give this Mono a chance to resolve within a specified time frame but complete if it
doesn't.
- take(Duration, Scheduler) - Method in class reactor.core.publisher.Mono
-
Give this Mono a chance to resolve within a specified time frame but complete if it
doesn't.
- 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
-
- takeUntilOther(Publisher<?>) - Method in class reactor.core.publisher.Mono
-
Give this Mono a chance to resolve before a companion
Publisher
emits.
- 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() - Method in class reactor.core.publisher.Operators.DeferredSubscription
-
- 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!
- TERMINATED - Static variable in class reactor.core.Scannable.Attr
-
A
Boolean
attribute indicating whether or not an upstream component
terminated this scanned component.
- 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.
- then() - Method in class reactor.core.publisher.ParallelFlux
-
Emit an onComplete or onError signal once all values across 'rails' have been observed.
- 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
-
- thenReturn(V) - Method in class reactor.core.publisher.Mono
-
Let this
Mono
complete successfully, then emit the provided value.
- 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.
- timed() - Method in class reactor.core.publisher.Flux
-
- timed(Scheduler) - Method in class reactor.core.publisher.Flux
-
- timed() - Method in class reactor.core.publisher.Mono
-
- timed(Scheduler) - Method in class reactor.core.publisher.Mono
-
- Timed<T> - Interface in reactor.core.publisher
-
- 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
).
- timestamp() - Method in interface reactor.core.publisher.Timed
-
Get the timestamp of the emission of this timed onNext, as an
Instant
.
- 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 Tuple
into a plain Object[]
.
- 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
-
- toConditionalSubscriber(CoreSubscriber<? super T>) - Static method in class reactor.core.publisher.Operators
-
- toCoreSubscriber(Subscriber<? super T>) - Static method in class reactor.core.publisher.Operators
-
If the actual
Subscriber
is not a
CoreSubscriber
, it will apply
safe strict wrapping to apply all reactive streams rules including the ones
relaxed by internal operators based on
CoreSubscriber
.
- toFuture() - Method in class reactor.core.publisher.Mono
-
- toIterable() - Method in class reactor.core.publisher.Flux
-
- toIterable(int) - Method in class reactor.core.publisher.Flux
-
- toIterable(int, Supplier<Queue<T>>) - Method in class reactor.core.publisher.Flux
-
- toList() - Method in class reactor.util.function.Tuple2
-
- toProcessor() - Method in class reactor.core.publisher.Mono
-
- 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.Mono
-
- toString() - Method in class reactor.core.publisher.ParallelFlux
-
- 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.
- totalRetries() - Method in interface reactor.util.retry.Retry.RetrySignal
-
The total number of retries since the source first was subscribed to (in other words the number of errors -1
since the source was first subscribed to).
- totalRetriesInARow() - Method in interface reactor.util.retry.Retry.RetrySignal
-
Retry counter resetting after each
onNext
(in other
words the number of errors -1 since the latest
onNext
).
- 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.
- transformDeferred(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.
- transformDeferred(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.
- transformDeferredContextual(BiFunction<? super Flux<T>, ? super ContextView, ? extends Publisher<V>>) - Method in class reactor.core.publisher.Flux
-
Defer the given transformation to this
Flux
in order to generate a
target
Flux
type.
- transformDeferredContextual(BiFunction<? super Mono<T>, ? super ContextView, ? 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.
- transformGroups(Function<? super GroupedFlux<Integer, T>, ? extends Publisher<? extends U>>) - Method in class reactor.core.publisher.ParallelFlux
-
Allows composing operators off the groups (or 'rails'), as individual
GroupedFlux
instances keyed by the zero based rail's index.
- transientErrors(boolean) - Method in class reactor.util.retry.RetryBackoffSpec
-
- transientErrors(boolean) - Method in class reactor.util.retry.RetrySpec
-
- tryEmitComplete() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- tryEmitComplete() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- tryEmitComplete() - Method in interface reactor.core.publisher.Sinks.Many
-
Try to terminate the sequence successfully, generating an
onComplete
signal.
- tryEmitComplete() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- tryEmitEmpty() - Method in interface reactor.core.publisher.Sinks.Empty
-
Try to complete the
Mono
without a value, generating only an
onComplete
signal.
- tryEmitError(Throwable) - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- tryEmitError(Throwable) - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- tryEmitError(Throwable) - Method in interface reactor.core.publisher.Sinks.Empty
-
Try to fail the
Mono
, generating only an
onError
signal.
- tryEmitError(Throwable) - Method in interface reactor.core.publisher.Sinks.Many
-
Try to fail the sequence, generating an
onError
signal.
- tryEmitError(Throwable) - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- tryEmitNext(T) - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- tryEmitNext(T) - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- tryEmitNext(T) - Method in interface reactor.core.publisher.Sinks.Many
-
Try emitting a non-null element, generating an
onNext
signal.
- tryEmitNext(T) - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- tryEmitValue(T) - Method in class reactor.core.publisher.SinkOneSerialized
-
- tryEmitValue(T) - Method in interface reactor.core.publisher.Sinks.One
-
Try to complete the
Mono
with an element, generating an
onNext
signal
immediately followed by an
onComplete
signal.
- 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 non-null values.
- Tuple3<T1,T2,T3> - Class in reactor.util.function
-
A tuple that holds three non-null values.
- Tuple4<T1,T2,T3,T4> - Class in reactor.util.function
-
A tuple that holds four non-null values
- Tuple5<T1,T2,T3,T4,T5> - Class in reactor.util.function
-
A tuple that holds five non-null 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 non-null 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.
- validate(Subscription, Subscription) - Static method in class reactor.core.publisher.Operators
-
Check Subscription current state and cancel new Subscription if current is set,
or return true if ready to subscribe.
- validate(long) - Static method in class reactor.core.publisher.Operators
-
- validate(Subscriber<?>[]) - Method in class reactor.core.publisher.ParallelFlux
-
Validates the number of subscribers and returns true if their number matches the
parallelism level of this ParallelFlux.
- validateArguments() - Method in class reactor.util.retry.RetryBackoffSpec
-
- value - Variable in class reactor.core.publisher.Operators.MonoSubscriber
-
The value stored by this Mono operator.
- valueOf(String) - Static method in enum reactor.core.publisher.BufferOverflowStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum reactor.core.publisher.FluxSink.OverflowStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum reactor.core.publisher.SignalType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum reactor.core.publisher.Sinks.EmitResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum reactor.core.Scannable.Attr.RunStyle
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum reactor.core.publisher.BufferOverflowStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum reactor.core.publisher.FluxSink.OverflowStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum reactor.core.publisher.SignalType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum reactor.core.publisher.Sinks.EmitResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum reactor.core.Scannable.Attr.RunStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- zip(Publisher<? extends T1>, Publisher<? extends T2>, BiFunction<? super T1, ? super T2, ? extends O>) - Static method in class reactor.core.publisher.Flux
-
Zip two sources together, that is to say wait for all the sources to emit one
element and combine these elements once into an output value (constructed by the provided
combinator).
- zip(Publisher<? extends T1>, Publisher<? extends T2>) - Static method in class reactor.core.publisher.Flux
-
Zip two sources together, that is to say wait for all the sources to emit one
element and combine these elements once into a
Tuple2
.
- zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>) - Static method in class reactor.core.publisher.Flux
-
Zip three sources together, that is to say wait for all the sources to emit one
element and combine these elements once into a
Tuple3
.
- zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>) - Static method in class reactor.core.publisher.Flux
-
Zip four sources together, that is to say wait for all the sources to emit one
element and combine these elements once into a
Tuple4
.
- zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>) - Static method in class reactor.core.publisher.Flux
-
Zip five sources together, that is to say wait for all the sources to emit one
element and combine these elements once into a
Tuple5
.
- zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>) - Static method in class reactor.core.publisher.Flux
-
Zip six sources together, that is to say wait for all the sources to emit one
element and combine these elements once into a
Tuple6
.
- zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>) - Static method in class reactor.core.publisher.Flux
-
Zip seven sources together, that is to say wait for all the sources to emit one
element and combine these elements once into a
Tuple7
.
- zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>) - Static method in class reactor.core.publisher.Flux
-
Zip eight sources together, that is to say wait for all the sources to emit one
element and combine these elements once into a
Tuple8
.
- zip(Iterable<? extends Publisher<?>>, Function<? super Object[], ? extends O>) - Static method in class reactor.core.publisher.Flux
-
Zip multiple sources together, that is to say wait for all the sources to emit one
element and combine these elements once into an output value (constructed by the provided
combinator).
- zip(Iterable<? extends Publisher<?>>, int, Function<? super Object[], ? extends O>) - Static method in class reactor.core.publisher.Flux
-
Zip multiple sources together, that is to say wait for all the sources to emit one
element and combine these elements once into an output value (constructed by the provided
combinator).
- zip(Function<? super Object[], ? extends O>, Publisher<? extends I>...) - Static method in class reactor.core.publisher.Flux
-
Zip multiple sources together, that is to say wait for all the sources to emit one
element and combine these elements once into an output value (constructed by the provided
combinator).
- zip(Function<? super Object[], ? extends O>, int, Publisher<? extends I>...) - Static method in class reactor.core.publisher.Flux
-
Zip multiple sources together, that is to say wait for all the sources to emit one
element and combine these elements once into an output value (constructed by the provided
combinator).
- zip(Publisher<? extends Publisher<?>>, Function<? super TUPLE, ? extends V>) - Static method in class reactor.core.publisher.Flux
-
Zip multiple sources together, that is to say wait for all the sources to emit one
element and combine these elements once into an output value (constructed by the provided
combinator).
- zip(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 produced an item, aggregating their values into a
Tuple2
.
- zip(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 produced an item, aggregating their values as defined by the combinator function.
- zip(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 produced an item, aggregating their values into a
Tuple3
.
- zip(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 produced an item, aggregating their values into a
Tuple4
.
- zip(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 produced an item, aggregating their values into a
Tuple5
.
- zip(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 produced an item, aggregating their values into a
Tuple6
.
- zip(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>, Mono<? extends T5>, Mono<? extends T6>, Mono<? extends T7>) - 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 produced an item, aggregating their values into a
Tuple7
.
- zip(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>, Mono<? extends T5>, Mono<? extends T6>, Mono<? extends T7>, Mono<? extends T8>) - 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 produced an item, aggregating their values into a
Tuple8
.
- zip(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 produced an item, aggregating their values according to the provided combinator function.
- zip(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 produced an item, aggregating their values according to the provided combinator function.
- zipDelayError(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 produced an item, aggregating their values into a
Tuple2
and delaying errors.
- zipDelayError(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 produced an item, aggregating their values into a
Tuple3
and delaying errors.
- zipDelayError(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 produced an item, aggregating their values into a
Tuple4
and delaying errors.
- zipDelayError(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 produced an item, aggregating their values into a
Tuple5
and delaying errors.
- zipDelayError(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 produced an item, aggregating their values into a
Tuple6
and delaying errors.
- zipDelayError(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>, Mono<? extends T5>, Mono<? extends T6>, Mono<? extends T7>) - 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 produced an item, aggregating their values into a
Tuple7
and delaying errors.
- zipDelayError(Mono<? extends T1>, Mono<? extends T2>, Mono<? extends T3>, Mono<? extends T4>, Mono<? extends T5>, Mono<? extends T6>, Mono<? extends T7>, Mono<? extends T8>) - 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 produced an item, aggregating their values into a
Tuple8
and delaying errors.
- zipDelayError(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 produced an item.
- zipDelayError(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 produced an item, aggregating their values according to
the provided combinator function and delaying errors.
- zipWhen(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
.
- zipWhen(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.
- zipWith(Publisher<? extends T2>) - Method in class reactor.core.publisher.Flux
-
Zip this
Flux
with another
Publisher
source, that is to say wait
for both to emit one element and combine these elements once into a
Tuple2
.
- zipWith(Publisher<? extends T2>, BiFunction<? super T, ? super T2, ? extends V>) - Method in class reactor.core.publisher.Flux
-
Zip this
Flux
with another
Publisher
source, that is to say wait
for both to emit one element and combine these elements using a
combinator
BiFunction
The operator will continue doing so until any of the sources completes.
- zipWith(Publisher<? extends T2>, int, BiFunction<? super T, ? super T2, ? extends V>) - Method in class reactor.core.publisher.Flux
-
Zip this
Flux
with another
Publisher
source, that is to say wait
for both to emit one element and combine these elements using a
combinator
BiFunction
The operator will continue doing so until any of the sources completes.
- zipWith(Publisher<? extends T2>, int) - Method in class reactor.core.publisher.Flux
-
Zip this
Flux
with another
Publisher
source, that is to say wait
for both to emit one element and combine these elements once into a
Tuple2
.
- zipWith(Mono<? extends T2>) - Method in class reactor.core.publisher.Mono
-
Combine the result from this mono and another into a
Tuple2
.
- zipWith(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.
- zipWithIterable(Iterable<? extends T2>) - Method in class reactor.core.publisher.Flux
-
Zip elements from this
Flux
with the content of an
Iterable
, that is
to say combine one element from each, pairwise, into a
Tuple2
.
- zipWithIterable(Iterable<? extends T2>, BiFunction<? super T, ? super T2, ? extends V>) - Method in class reactor.core.publisher.Flux
-
Zip elements from this
Flux
with the content of an
Iterable
, that is
to say combine one element from each, pairwise, using the given zipper
BiFunction
.