Skip navigation links
Reactor Core
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

E

elapsed() - Method in class reactor.core.publisher.Flux
Map this Flux into Tuple2<Long, T> of timemillis and source data.
elapsed(Scheduler) - Method in class reactor.core.publisher.Flux
Map this Flux into Tuple2<Long, T> of timemillis and source data.
elapsed() - Method in class reactor.core.publisher.Mono
Map this Mono into Tuple2<Long, T> of timemillis and source data.
elapsed(Scheduler) - Method in class reactor.core.publisher.Mono
Map this Mono sequence into Tuple2<Long, T> of timemillis and source data.
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).
element() - Method in interface reactor.core.Fuseable.QueueSubscription
 
elementAt(int) - Method in class reactor.core.publisher.Flux
Emit only the element at the given index position or IndexOutOfBoundsException if the sequence is shorter.
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
 
emit(T...) - Method in class reactor.test.publisher.TestPublisher
Combine emitting items and completing this publisher.
emitComplete(Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Many
A simplified attempt at completing via the Sinks.Many.tryEmitComplete() API, generating an onComplete signal.
emitEmpty(Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Empty
A simplified attempt at completing via the Sinks.Empty.tryEmitEmpty() API, generating an onComplete signal.
emitError(Throwable, Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Empty
A simplified attempt at failing the sequence via the Sinks.Empty.tryEmitError(Throwable) API, generating an onError signal.
emitError(Throwable, Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Many
A simplified attempt at failing the sequence via the Sinks.Many.tryEmitError(Throwable) API, generating an onError signal.
emitNext(T, Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.Many
A simplified attempt at emitting a non-null element via the Sinks.Many.tryEmitNext(Object) API, generating an onNext signal.
emitNext(T, Sinks.EmitFailureHandler) - Method in class reactor.core.publisher.UnicastProcessor
Deprecated.
 
EmitterProcessor<T> - Class in reactor.core.publisher
Deprecated.
To be removed in 3.5. Prefer clear cut usage of Sinks through variations of Sinks.many().multicast().onBackpressureBuffer(). If you really need the subscribe-to-upstream functionality of a Processor, switch to Sinks.ManyWithUpstream with Sinks.unsafe() variants of Sinks.unsafe().manyWithUpstream().

This processor was blocking in EmitterProcessor.onNext(Object). This behaviour can be implemented with the Sinks API by calling Sinks.Many.tryEmitNext(Object) and retrying, e.g.:

 while (sink.tryEmitNext(v).hasFailed()) {
     LockSupport.parkNanos(10);
 }
 
emitValue(T, Sinks.EmitFailureHandler) - Method in interface reactor.core.publisher.Sinks.One
A simplified attempt at emitting a non-null element via the Sinks.One.tryEmitValue(Object) API, generating an onNext signal immediately followed by an Subscriber.onComplete() signal.
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 interface reactor.test.publisher.PublisherProbe
Create a PublisherProbe of which PublisherProbe.flux() and PublisherProbe.mono() versions will simply complete, capturing subscription, cancellation and request events around them.
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
Return an empty 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.
enableAutomaticContextPropagation() - Static method in class reactor.core.publisher.Hooks
Globally enables automatic context propagation to ThreadLocals.
enableCaptureWith(Logger) - Static method in class reactor.test.util.LoggerUtils
Set the logger used for capturing.
enableCaptureWith(Logger, boolean) - Static method in class reactor.test.util.LoggerUtils
Set the logger used for capturing, an optionally suppress log messages from original logger.
enableConditionalSupport(Predicate<? super T>) - Method in interface reactor.test.StepVerifier.FirstStep
Provide a Predicate that will turn this StepVerifier's subscribers into Fuseable.ConditionalSubscriber and drive the Fuseable.ConditionalSubscriber.tryOnNext(Object) behavior of these subscribers.
enableContextLossTracking() - Static method in class reactor.core.publisher.Hooks
enableMetrics() - Static method in class reactor.core.scheduler.Schedulers
Deprecated.
prefer using Micrometer#timedScheduler from the reactor-core-micrometer module. To be removed at the earliest in 3.6.0.
enableOnDiscard(Context, Consumer<?>) - Static method in class reactor.core.publisher.Operators
Utility method to activate the onDiscard feature (see Flux.doOnDiscard(Class, Consumer)) in a target Context.
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(Throwable) - Method in class reactor.test.publisher.TestPublisher
Triggers an error signal to the subscribers.
error(String) - Method in class reactor.test.util.TestLogger
 
error(String, Object...) - Method in class reactor.test.util.TestLogger
 
error(String, Throwable) - Method in class reactor.test.util.TestLogger
 
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
Return an UnsupportedOperationException indicating that the error callback on a subscriber was not implemented, yet an error was propagated.
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.
errorOrDebug(Logger.ChoiceOfMessageSupplier) - Method in interface reactor.util.Logger
Convenience method to log a message that is different according to the log level.
errorOrDebug(Logger.ChoiceOfMessageSupplier, Throwable) - Method in interface reactor.util.Logger
Convenience method to log an exception (throwable), with an accompanying message that is different according to the log level.
Exceptions - Class in reactor.core
Global Reactor Core Exception handling and utils to operate on.
Exceptions.SourceException - Exception in reactor.core
A Throwable that wraps the actual cause delivered via Subscriber.onError(Throwable) in case of Publishers that themselves emit items of type Publisher.
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.
expectAccessibleContext() - Method in interface reactor.test.StepVerifier.Step
Expect that after the Subscription step, a Context has been propagated.
expectComplete() - Method in interface reactor.test.StepVerifier.LastStep
Expect the completion signal.
expectError() - Method in interface reactor.test.StepVerifier.LastStep
Expect an unspecified error.
expectError(Class<? extends Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error of the specified type.
expectErrorMatches(Predicate<Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error and evaluate with the given predicate.
expectErrorMessage(String) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error with the specified message.
expectErrorSatisfies(Consumer<Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error and assert it via assertion(s) provided as a Consumer.
expectFusion() - Method in interface reactor.test.StepVerifier.FirstStep
Expect the source Publisher to run with Reactor Fusion flow optimization.
expectFusion(int) - Method in interface reactor.test.StepVerifier.FirstStep
Expect the source Publisher to run the requested Reactor Fusion mode from any of these modes : Fuseable.NONE, Fuseable.SYNC, Fuseable.ASYNC, Fuseable.ANY, Fuseable.THREAD_BARRIER.
expectFusion(int, int) - Method in interface reactor.test.StepVerifier.FirstStep
Expect the source Publisher to run with Reactor Fusion flow optimization.
expectNext(T) - Method in interface reactor.test.StepVerifier.Step
Expect the next element received to be equal to the given value.
expectNext(T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T, T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T, T, T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T, T, T, T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T, T, T, T, T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T...) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNextCount(long) - Method in interface reactor.test.StepVerifier.Step
Expect to received count elements, starting from the previous expectation or onSubscribe.
expectNextMatches(Predicate<? super T>) - Method in interface reactor.test.StepVerifier.Step
Expect an element and evaluate with the given predicate.
expectNextSequence(Iterable<? extends T>) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements to match the given Iterable until its iterator depletes.
expectNoAccessibleContext() - Method in interface reactor.test.StepVerifier.Step
Expect that NO Context was propagated after the Subscription phase, which usually indicates that the sequence under test doesn't contain Reactor operators (i.e.
expectNoEvent(Duration) - Method in interface reactor.test.StepVerifier.Step
Expect that no event has been observed by the verifier for the length of the provided Duration.
expectNoFusionSupport() - Method in interface reactor.test.StepVerifier.FirstStep
Expect the source Publisher to NOT run with Reactor Fusion flow optimization.
expectRecordedMatches(Predicate<? super Collection<T>>) - Method in interface reactor.test.StepVerifier.Step
Expect a recording session started via StepVerifier.Step.recordWith(java.util.function.Supplier<? extends java.util.Collection<T>>), end it and verify it by ensuring the provided predicate matches.
expectSubscription() - Method in interface reactor.test.StepVerifier.FirstStep
Expect a Subscription.
expectSubscriptionMatches(Predicate<? super Subscription>) - Method in interface reactor.test.StepVerifier.FirstStep
Expect a Subscription and evaluate with the given predicate.
expectTerminalError() - Method in interface reactor.test.subscriber.TestSubscriber
Expect the TestSubscriber to be terminated with an Subscriber.onError(Throwable) and return the terminating Throwable if so.
expectTerminalSignal() - Method in interface reactor.test.subscriber.TestSubscriber
Expect the TestSubscriber to be terminated, and return the terminal Signal if so.
expectTimeout(Duration) - Method in interface reactor.test.StepVerifier.LastStep
Verify that the Publisher under test doesn't terminate but rather times out after the provided Duration (a timeout implying a cancellation of the source).
explode(CONTAINER) - Method in interface reactor.test.ValueFormatters.Extractor
Explode the container into a Stream of Object, each of which is a candidate for individual String conversion by a ValueFormatters.ToStringConverter when applied as a BiFunction.
extractor(ValueFormatters.Extractor<T>) - Method in class reactor.test.StepVerifierOptions
Add an ValueFormatters.Extractor, replacing any existing ValueFormatters.Extractor that targets the same Class (as in ValueFormatters.Extractor.getTargetClass()).
A B C D E F G H I J K L M N O P Q R S T U V W X Z 
Skip navigation links
Reactor Core