- debug(String) - Method in class reactor.test.util.TestLogger
-
- debug(String, Object...) - Method in class reactor.test.util.TestLogger
-
- debug(String, Throwable) - Method in class reactor.test.util.TestLogger
-
- 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_METER_PREFIX - Static variable in class reactor.core.observability.micrometer.Micrometer
-
The default "name" to use as a prefix for meter if the instrumented sequence doesn't define a
name
.
- 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.
- DEFAULT_VERIFY_TIMEOUT - Static variable in interface reactor.test.StepVerifier
-
- 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
- DefaultSignalListener<T> - Class in reactor.core.observability
-
A default implementation of a
SignalListener
with all the handlers no-op.
- DefaultSignalListener() - Constructor for class reactor.core.observability.DefaultSignalListener
-
- 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
-
- 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
-
- disableAutomaticContextPropagation() - Static method in class reactor.core.publisher.Hooks
-
Globally disables automatic context propagation to
ThreadLocal
s.
- disableCapture() - Static method in class reactor.test.util.LoggerUtils
-
- 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
-
- dispose() - Method in class reactor.test.scheduler.VirtualTimeScheduler
-
- disposed() - Static method in class reactor.core.Disposables
-
- disposeGracefully() - Method in interface reactor.core.scheduler.Scheduler
-
Lazy variant of
Scheduler.dispose()
that also allows for graceful cleanup
of underlying resources.
- 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
.
- doAfterComplete() - Method in class reactor.core.observability.DefaultSignalListener
-
- doAfterComplete() - Method in interface reactor.core.observability.SignalListener
-
Handle graceful onComplete sequence termination, after onComplete has been propagated downstream.
- doAfterError(Throwable) - Method in class reactor.core.observability.DefaultSignalListener
-
- doAfterError(Throwable) - Method in interface reactor.core.observability.SignalListener
-
Handle onError sequence termination after onError has been propagated downstream.
- 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
.
- 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(SignalType) - Method in class reactor.core.observability.DefaultSignalListener
-
- doFinally(SignalType) - Method in interface reactor.core.observability.SignalListener
-
Handle terminal signals after the signals have been propagated, as the final step.
- 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() - Method in class reactor.core.observability.DefaultSignalListener
-
- doFirst() - Method in interface reactor.core.observability.SignalListener
-
- 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() - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnCancel() - Method in interface reactor.core.observability.SignalListener
-
Handle the downstream cancelling its currently observed
Subscription
.
- 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() - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnComplete() - Method in interface reactor.core.observability.SignalListener
-
Handle graceful onComplete sequence termination.
- 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(Throwable) - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnError(Throwable) - Method in interface reactor.core.observability.SignalListener
-
Handle onError sequence termination.
- 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'.
- doOnFusion(int) - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnFusion(int) - Method in interface reactor.core.observability.SignalListener
-
Handle the negotiation of fusion between two
Fuseable
operators.
- doOnMalformedOnComplete() - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnMalformedOnComplete() - Method in interface reactor.core.observability.SignalListener
-
- doOnMalformedOnError(Throwable) - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnMalformedOnError(Throwable) - Method in interface reactor.core.observability.SignalListener
-
- doOnMalformedOnNext(T) - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnMalformedOnNext(T) - Method in interface reactor.core.observability.SignalListener
-
- doOnNext(T) - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnNext(T) - Method in interface reactor.core.observability.SignalListener
-
Handle a new value emission from the source.
- 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(long) - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnRequest(long) - Method in interface reactor.core.observability.SignalListener
-
Handle a new request made by the downstream, exposing the demand.
- 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.
- doOnSubscription() - Method in class reactor.core.observability.DefaultSignalListener
-
- doOnSubscription() - Method in interface reactor.core.observability.SignalListener
-
- 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.
- 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
-
- DURATION_CONVERTER - Static variable in class reactor.test.ValueFormatters
-