- 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.
- filtering(Predicate<Object>, Function<Object, String>) - Static method in class reactor.test.ValueFormatters
-
Create a value formatter that applies the given String conversion
Function
only to objects matching a given
Predicate
- 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
-
- flux() - Method in class reactor.test.publisher.PublisherProbe.DefaultPublisherProbe
-
- flux() - Method in interface reactor.test.publisher.PublisherProbe
-
Return a
Flux
version of the probe.
- flux() - Method in class reactor.test.publisher.TestPublisher
-
- 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.
- forClass(Class<T>, Function<T, String>) - Static method in class reactor.test.ValueFormatters
-
Create a value formatter that is specific to a particular
Class
, applying
the given String conversion
Function
provided the object is an instance of
that Class.
- forClassMatching(Class<T>, Predicate<T>, Function<T, String>) - Static method in class reactor.test.ValueFormatters
-
Create a value formatter that is specific to a particular
Class
and filters
based on a provided
Predicate
.
- forEach(BiConsumer<Object, Object>) - Method in interface reactor.util.context.ContextView
-
Perform the given action for each entry in this
ContextView
.
- 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
-
Create a
Mono
, producing its value using the provided
CompletableFuture
and cancelling the future if the Mono gets cancelled.
- fromFuture(CompletableFuture<? extends T>, boolean) - Static method in class reactor.core.publisher.Mono
-
Create a
Mono
, producing its value using the provided
CompletableFuture
and optionally cancelling the future if the Mono gets cancelled (if
suppressCancel == false
).
- fromFuture(Supplier<? extends CompletableFuture<? extends T>>) - Static method in class reactor.core.publisher.Mono
-
Create a
Mono
that wraps a lazily-supplied
CompletableFuture
on subscription,
emitting the value produced by the future and cancelling the future if the Mono gets cancelled.
- fromFuture(Supplier<? extends CompletableFuture<? extends T>>, boolean) - Static method in class reactor.core.publisher.Mono
-
Create a
Mono
that wraps a lazily-supplied
CompletableFuture
on subscription,
emitting the value produced by the future and optionally cancelling the future if the Mono gets cancelled
(if
suppressCancel == false
).
- 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.
- fusionModeName(int) - Static method in interface reactor.core.Fuseable
-
Attempt to convert a fusion mode int code into a human-readable representation.
- fusionModeName(int, boolean) - Static method in interface reactor.core.Fuseable
-
Attempt to convert a fusion mode int code into a human-readable representation.