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 

S

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.
scenarioName(String) - Method in class reactor.test.StepVerifierOptions
Give a name to the whole scenario tested by the configured StepVerifier.
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.
schedule(Runnable) - Method in class reactor.test.scheduler.VirtualTimeScheduler
 
schedule(Runnable, long, TimeUnit) - Method in class reactor.test.scheduler.VirtualTimeScheduler
 
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.
schedulePeriodically(Runnable, long, long, TimeUnit) - Method in class reactor.test.scheduler.VirtualTimeScheduler
 
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 provides various Scheduler flavors usable by publishOn or subscribeOn :
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
It is also Disposable in case you don't want to restore the live Schedulers
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.
Create a FluxProcessor that safely gates multi-threaded producer Subscriber.onNext(Object).
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.
set(VirtualTimeScheduler) - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Assign an externally created VirtualTimeScheduler to the relevant Schedulers.Factory factories, depending on how it was created (see VirtualTimeScheduler.create() and VirtualTimeScheduler.create()).
setDefaultTimeout(Duration) - Static method in interface reactor.test.StepVerifier
Set the StepVerifier.verify() timeout for all StepVerifier created through the factory methods (StepVerifier.create(Publisher), StepVerifier.withVirtualTime(Supplier), etc.).
setExecutorServiceDecorator(String, BiFunction<Scheduler, ScheduledExecutorService, ScheduledExecutorService>) - Static method in class reactor.core.scheduler.Schedulers
Set up an additional ScheduledExecutorService decorator for a given key, even if that key is already present.
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
Prepare a Mono which shares this Mono result similar to Flux.shareNext().
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.
signalExtractor() - Static method in class reactor.test.ValueFormatters
Default Signal extractor that unwraps only onNext.
SignalListener<T> - Interface in reactor.core.observability
A listener which combines various handlers to be triggered per the corresponding Flux or Mono signals.
SignalListenerFactory<T,STATE> - Interface in reactor.core.observability
A factory for per-subscription SignalListener, exposing the ability to generate common state at publisher level from the source Publisher.
SignalType - Enum in reactor.core.publisher
Reactive Stream signal types
single() - Static method in class reactor.core.Disposables
Return a new simple Disposable instance that is initially not disposed but can be by calling Disposable.dispose().
single() - Method in class reactor.core.publisher.Flux
Expect and emit a single item from this Flux source or signal NoSuchElementException for an empty source, or IndexOutOfBoundsException for a source with more than one element.
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
Expect exactly one item from this Mono source or signal NoSuchElementException for an empty source.
single() - Static method in class reactor.core.scheduler.Schedulers
The common single instance, a Scheduler that hosts a single-threaded ExecutorService-based worker.
single(Scheduler) - Static method in class reactor.core.scheduler.Schedulers
Wraps a single Scheduler.Worker from some other Scheduler and provides Scheduler.Worker services on top of it.
singleOptional() - Method in class reactor.core.publisher.Mono
Wrap the item produced by this Mono source into an Optional or emit an empty Optional for an empty source.
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
Deprecated.
To be removed in 3.5, prefer clear cut usage of Sinks through the Sinks.many() spec.
sink(FluxSink.OverflowStrategy) - Method in class reactor.core.publisher.FluxProcessor
Deprecated.
To be removed in 3.5, prefer clear cut usage of Sinks through the Sinks.many() spec.
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
An exception representing a failed Sinks.EmitResult.
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.ManyWithUpstream<T> - Interface in reactor.core.publisher
A Sinks.Many which additionally allows being subscribed to an upstream Publisher, which is an advanced pattern requiring external synchronization.
Sinks.ManyWithUpstreamUnsafeSpec - Interface in reactor.core.publisher
Instead of unsafe flavors of Sinks.Many, this spec provides Sinks.ManyWithUpstream implementations.
Sinks.MulticastReplaySpec - Interface in reactor.core.publisher
Provides multicast with history/replay capacity : 1 sink, N Subscriber
Sinks.MulticastSpec - Interface in reactor.core.publisher
Provides multicast : 1 sink, N Subscriber
Sinks.One<T> - Interface in reactor.core.publisher
A base interface for standalone Sinks with Mono semantics.
Sinks.RootSpec - Interface in reactor.core.publisher
Provides a choice of Sinks.One/Sinks.Empty factories and further specs for Sinks.Many.
Sinks.UnicastSpec - Interface in reactor.core.publisher
Provides unicast: 1 sink, 1 Subscriber
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
Deprecated.
Use Scheduler.init() instead. The use of this method is discouraged. Some implementations allowed restarting a Scheduler, while others did not. One of the issues with restarting is that checking the disposed state is unreliable in concurrent scenarios.
startWith(Iterable<? extends T>) - Method in class reactor.core.publisher.Flux
Prepend the given Iterable before this Flux sequence.
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
Prepend the given Publisher sequence to this Flux sequence.
stepName() - Method in interface reactor.core.Scannable
Return a meaningful String representation of this Scannable in its chain of Scannable.parents() and Scannable.actuals().
steps() - Method in interface reactor.core.Scannable
List the step names in the chain of Scannable (including the current element), in their assembly order.
StepVerifier - Interface in reactor.test
A StepVerifier provides a declarative way of creating a verifiable script for an async Publisher sequence, by expressing expectations about the events that will happen upon subscription.
StepVerifier.Assertions - Interface in reactor.test
Exposes post-verification state assertions.
StepVerifier.ContextExpectations<T> - Interface in reactor.test
Allow to set expectations about the Context propagated during the Subscription phase.
StepVerifier.FirstStep<T> - Interface in reactor.test
Define a builder for explicitly expecting an initializing Subscription as first signal.
StepVerifier.LastStep - Interface in reactor.test
Define a builder for terminal states.
StepVerifier.Step<T> - Interface in reactor.test
Define a builder for expecting main sequence individual signals.
StepVerifierOptions - Class in reactor.test
Options for a StepVerifier, including the initial request amount, VirtualTimeScheduler supplier and toggles for some checks.
stream() - Method in interface reactor.util.context.ContextView
Stream key/value pairs from this Context
SUBMISSION_DELAYED - Static variable in enum reactor.core.observability.micrometer.TimedSchedulerMeterDocumentation.SubmittedTags
Counter that increments by one each time a task is submitted with a delay (ie.
SUBMISSION_DIRECT - Static variable in enum reactor.core.observability.micrometer.TimedSchedulerMeterDocumentation.SubmittedTags
Counter that increments by one each time a task is submitted for immediate execution (ie.
SUBMISSION_PERIODIC_INITIAL - Static variable in enum reactor.core.observability.micrometer.TimedSchedulerMeterDocumentation.SubmittedTags
Counter that increments when a task is initially submitted with a period (ie.
SUBMISSION_PERIODIC_ITERATION - Static variable in enum reactor.core.observability.micrometer.TimedSchedulerMeterDocumentation.SubmittedTags
Counter that increments by one each time a task is re-executed due to the periodic nature of Scheduler#schedulePeriodically(Runnable, long, long, TimeUnit) or Scheduler.Worker#schedulePeriodically(Runnable, long, long, TimeUnit) (ie.
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
Deprecated.
Because users tend to forget to request the subsciption. If the behavior is really needed, consider using Flux.subscribeWith(Subscriber). To be removed in 3.5.
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
Merge the rails into a ParallelFlux.sequential() Flux and subscribe to said Flux.
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.
 
subscribeCount() - Method in class reactor.test.publisher.PublisherProbe.DefaultPublisherProbe
 
subscribeCount() - Method in interface reactor.test.publisher.PublisherProbe
 
subscribeOn(Scheduler) - Method in class reactor.core.publisher.Flux
Run subscribe, onSubscribe and request on a specified Scheduler's Scheduler.Worker.
subscribeOn(Scheduler, boolean) - Method in class reactor.core.publisher.Flux
Run subscribe and onSubscribe on a specified Scheduler's Scheduler.Worker.
subscribeOn(Scheduler) - Method in class reactor.core.publisher.Mono
Run subscribe, onSubscribe and request on a specified Scheduler's Scheduler.Worker.
subscribeTo(Publisher<? extends T>) - Method in class reactor.core.publisher.EmitterProcessor
Deprecated.
 
subscribeTo(Publisher<? extends T>) - Method in interface reactor.core.publisher.Sinks.ManyWithUpstream
Explicitly subscribe this Sinks.Many to an upstream Publisher without exposing it as a Subscriber at all.
subscribeWith(E) - Method in class reactor.core.publisher.Flux
Subscribe a provided instance of a subclass of Subscriber to this Flux and return said instance for further chaining calls.
subscribeWith(E) - Method in class reactor.core.publisher.Mono
Subscribe the given Subscriber to this Mono and return said Subscriber, allowing subclasses with a richer API to be used fluently.
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.
suffix(CONTAINER) - Method in interface reactor.test.ValueFormatters.Extractor
Return the suffix to use in the container's String representation, given the original container.
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
Switch to a new Publisher generated via a Function whenever this Flux produces an item.
switchMap(Function<? super T, Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
Deprecated.
to be removed in 3.6.0 at the earliest. In 3.5.0, you should replace calls with prefetch=0 with calls to switchMap(fn), as the default behavior of the single-parameter variant will then change to prefetch=0.
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 the source.
switchOnNext(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
Deprecated.
to be removed in 3.6.0 at the earliest. In 3.5.0, you should replace calls with prefetch=0 with calls to switchOnNext(mergedPublishers), as the default behavior of the single-parameter variant will then change to prefetch=0.
switchOnNext() - Static method in class reactor.core.publisher.FluxProcessor
Deprecated.
should use Sinks, Sinks.Many.asFlux() and Flux.switchOnNext(Publisher). To be removed in 3.5.0.
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.
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