- observation(ObservationRegistry) - Static method in class reactor.core.observability.micrometer.Micrometer
-
A
SignalListener
factory that will ultimately produce a Micrometer
Observation
representing the runtime of the publisher to the provided
ObservationRegistry
.
- observation(ObservationRegistry, Function<ObservationRegistry, Observation>) - Static method in class reactor.core.observability.micrometer.Micrometer
-
- of(Publisher<? extends T>) - Static method in interface reactor.test.publisher.PublisherProbe
-
- 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
.
- onDiscardMultiple(Spliterator<?>, boolean, Context) - Static method in class reactor.core.publisher.Operators
-
Invoke a (local or global) hook that processes elements that remains in an
Spliterator
.
- 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.
- onErrorComplete() - Method in class reactor.core.publisher.Flux
-
- onErrorComplete(Class<? extends Throwable>) - Method in class reactor.core.publisher.Flux
-
- onErrorComplete(Predicate<? super Throwable>) - Method in class reactor.core.publisher.Flux
-
- onErrorComplete() - Method in class reactor.core.publisher.Mono
-
- onErrorComplete(Class<? extends Throwable>) - Method in class reactor.core.publisher.Mono
-
- onErrorComplete(Predicate<? super Throwable>) - Method in class reactor.core.publisher.Mono
-
- 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
-
- onHandleError(String, 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
-