- AbstractRetry<T,S> - Class in reactor.retry
-
- accept(T1, T2, T3) - Method in interface reactor.function.Consumer3
-
Performs this operation on the given arguments.
- accept(T1, T2, T3, T4) - Method in interface reactor.function.Consumer4
-
Performs this operation on the given arguments.
- accept(T1, T2, T3, T4, T5) - Method in interface reactor.function.Consumer5
-
Performs this operation on the given arguments.
- accept(T1, T2, T3, T4, T5, T6) - Method in interface reactor.function.Consumer6
-
Performs this operation on the given arguments.
- accept(T1, T2, T3, T4, T5, T6, T7) - Method in interface reactor.function.Consumer7
-
Performs this operation on the given arguments.
- accept(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface reactor.function.Consumer8
-
Performs this operation on the given arguments.
- alert() - Static method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
- allBut(Class<? extends Throwable>...) - Static method in interface reactor.retry.Retry
-
Returns a retry function that retries errors resulting from all exceptions except
the specified non-retriable exceptions, once.
- and(Mono<Boolean>, Mono<Boolean>) - Static method in class reactor.bool.BooleanUtils
-
Two booleans, wrapped in
Mono
, combined with the AND operator.
- andWriteWith(BiFunction<KEY, List<Signal<VALUE>>, Mono<Void>>) - Method in interface reactor.cache.CacheFlux.FluxCacheBuilderCacheWriter
-
- andWriteWith(BiFunction<KEY, Signal<? extends VALUE>, Mono<Void>>) - Method in interface reactor.cache.CacheMono.MonoCacheBuilderCacheWriter
-
- any() - Static method in interface reactor.retry.Retry
-
Returns a retry function that retries any exception, once.
- anyOf(Class<? extends Throwable>...) - Static method in interface reactor.retry.Retry
-
Returns a retry function that retries errors resulting from any of the
specified exceptions, once.
- applicationContext() - Method in class reactor.retry.DefaultContext
-
- applicationContext() - Method in interface reactor.retry.IterationContext
-
Application context that may be used to perform any rollbacks before
a retry.
- apply(T1, T2, T3) - Method in interface reactor.function.Function3
-
Applies this function to the given arguments.
- apply(T1, T2, T3, T4) - Method in interface reactor.function.Function4
-
Applies this function to the given arguments.
- apply(T1, T2, T3, T4, T5) - Method in interface reactor.function.Function5
-
Applies this function to the given arguments.
- apply(T1, T2, T3, T4, T5, T6) - Method in interface reactor.function.Function6
-
Applies this function to the given arguments.
- apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface reactor.function.Function7
-
Applies this function to the given arguments.
- apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface reactor.function.Function8
-
Applies this function to the given arguments.
- apply(Flux<Long>) - Method in class reactor.retry.DefaultRepeat
-
- apply(Flux<Throwable>) - Method in class reactor.retry.DefaultRetry
-
- apply(Publisher<S>) - Method in interface reactor.retry.Repeat
-
Transforms the source into a repeating
Flux
based on the properties
configured for this function.
- apply(Publisher<S>) - Method in interface reactor.retry.Retry
-
Transforms the source into a retrying
Flux
based on the properties
configured for this function.
- autoCancel(boolean) - Method in class reactor.extra.processor.TopicProcessor.Builder
-
Deprecated.
Configures auto-cancel for this builder.
- autoCancel(boolean) - Method in class reactor.extra.processor.WorkQueueProcessor.Builder
-
Deprecated.
Configures auto-cancel for this builder.
- averageBigDecimal(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the
BigDecimal
average of items in the source.
- averageBigDecimal(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the
BigDecimal
average of items in the source, which are mapped to
numerical values using the provided mapping.
- averageBigInteger(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the
BigInteger
average of items in the source.
- averageBigInteger(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the
BigInteger
average of items in the source, which are mapped to
numerical values using the provided mapping.
- averageDouble(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the double average of items in the source.
- averageDouble(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the double average of items in the source, which are mapped to numerical values
using the provided mapping.
- averageFloat(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the float average of items in the source.
- averageFloat(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the float average of items in the source, which are mapped to numerical values
using the provided mapping.
- CacheFlux - Class in reactor.cache
-
Opinionated caching helper that defines how to store and restore a
Flux
in an
arbitrary cache abstraction.
- CacheFlux.FluxCacheBuilderCacheMiss<KEY,VALUE> - Interface in reactor.cache
-
Setup original source to fallback to in case of cache miss.
- CacheFlux.FluxCacheBuilderCacheWriter<KEY,VALUE> - Interface in reactor.cache
-
- CacheFlux.FluxCacheBuilderMapMiss<VALUE> - Interface in reactor.cache
-
Setup original source to fallback to in case of cache miss and return a wrapped
Flux
that transparently looks up data from a
Map
representation of
a cache and store data into the cache in case of cache miss.
- CacheMono - Class in reactor.cache
-
Opinionated caching helper that defines how to store and restore a
Mono
in an
arbitrary cache abstraction.
- CacheMono.MonoCacheBuilderCacheMiss<KEY,VALUE> - Interface in reactor.cache
-
Setup original source to fallback to in case of cache miss.
- CacheMono.MonoCacheBuilderCacheWriter<KEY,VALUE> - Interface in reactor.cache
-
- CacheMono.MonoCacheBuilderMapMiss<VALUE> - Interface in reactor.cache
-
Setup original source to fallback to in case of cache miss and return a wrapped
Mono
that transparently looks up data from a
Map
representation of
a cache and store data into the cache in case of cache miss.
- companionValue() - Method in class reactor.retry.DefaultContext
-
- companionValue() - Method in interface reactor.retry.RepeatContext
-
Returns the value provided in the companion Flux for repeats.
- consumer(BiConsumer<T1, T2>) - Static method in class reactor.function.TupleUtils
-
Returns a
Consumer
of
Tuple2
that wraps a consumer of the component values of the tuple
- consumer(Consumer3<T1, T2, T3>) - Static method in class reactor.function.TupleUtils
-
Returns a
Consumer
of
Tuple3
that wraps a consumer of the component values of the tuple
- consumer(Consumer4<T1, T2, T3, T4>) - Static method in class reactor.function.TupleUtils
-
Returns a
Consumer
of
Tuple4
that wraps a consumer of the component values of the tuple
- consumer(Consumer5<T1, T2, T3, T4, T5>) - Static method in class reactor.function.TupleUtils
-
Returns a
Consumer
of
Tuple5
that wraps a consumer of the component values of the tuple
- consumer(Consumer6<T1, T2, T3, T4, T5, T6>) - Static method in class reactor.function.TupleUtils
-
Returns a
Consumer
of
Tuple6
that wraps a consumer of the component values of the tuple
- consumer(Consumer7<T1, T2, T3, T4, T5, T6, T7>) - Static method in class reactor.function.TupleUtils
-
Returns a
Consumer
of
Tuple7
that wraps a consumer of the component values of the tuple
- consumer(Consumer8<T1, T2, T3, T4, T5, T6, T7, T8>) - Static method in class reactor.function.TupleUtils
-
Returns a
Consumer
of
Tuple8
that wraps a consumer of the component values of the tuple
- Consumer3<T1,T2,T3> - Interface in reactor.function
-
An operation that accepts three input arguments and returns no result.
- Consumer4<T1,T2,T3,T4> - Interface in reactor.function
-
An operation that accepts four input arguments and returns no result.
- Consumer5<T1,T2,T3,T4,T5> - Interface in reactor.function
-
An operation that accepts five input arguments and returns no result.
- Consumer6<T1,T2,T3,T4,T5,T6> - Interface in reactor.function
-
An operation that accepts six input arguments and returns no result.
- Consumer7<T1,T2,T3,T4,T5,T6,T7> - Interface in reactor.function
-
An operation that accepts seven input arguments and returns no result.
- Consumer8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in reactor.function
-
An operation that accepts eight input arguments and returns no result.
- create() - Static method in class reactor.extra.processor.TopicProcessor
-
Deprecated.
- create(String, int) - Static method in class reactor.extra.processor.TopicProcessor
-
Deprecated.
Create a new TopicProcessor using the provided backlog size, with a blockingWait Strategy
and auto-cancellation.
- create() - Static method in class reactor.extra.processor.WorkQueueProcessor
-
Deprecated.
- create(String, int) - Static method in class reactor.extra.processor.WorkQueueProcessor
-
Deprecated.
Create a new WorkQueueProcessor using the passed buffer size, blockingWait
Strategy and auto-cancel.
- create(Predicate<? super RepeatContext<T>>, long) - Static method in class reactor.retry.DefaultRepeat
-
- create(Predicate<? super RetryContext<T>>) - Static method in class reactor.retry.DefaultRetry
-
- create(Predicate<? super RepeatContext<T>>, long) - Static method in interface reactor.retry.Repeat
-
Repeat function that repeats n times, only if the predicate returns true.
- create(String) - Static method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
-
Scheduler
that hosts a fixed pool of single-threaded ExecutorService-based
workers and is suited for parallel work.
- create(String, int) - Static method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
-
- create(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Scheduler) - Static method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
-
- create() - Static method in class reactor.swing.SwingScheduler
-
- createWorker() - Method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
-
- createWorker() - Method in class reactor.swing.SwingScheduler
-
- createWorker() - Method in class reactor.swing.SwtScheduler
-
- parking() - Static method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
Parking strategy that initially spins, then uses a Thread.yield(), and eventually sleep
(LockSupport.parkNanos(1)
) for the minimum number of nanos the OS and JVM will allow while the
consumers are waiting on a barrier.
- parking(int) - Static method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
Parking strategy that initially spins, then uses a Thread.yield(), and eventually
sleep (LockSupport.parkNanos(1)
) for the minimum number of nanos the
OS and JVM will allow while the consumers are waiting on a barrier.
- phasedOff(long, long, TimeUnit, WaitStrategy) - Static method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
Phased wait strategy for waiting consumers on a barrier.
- phasedOffLiteLock(long, long, TimeUnit) - Static method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
Block with wait/notifyAll semantics
- phasedOffLock(long, long, TimeUnit) - Static method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
Block with wait/notifyAll semantics
- phasedOffSleep(long, long, TimeUnit) - Static method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
Block by parking in a loop
- predicate(BiPredicate<T1, T2>) - Static method in class reactor.function.TupleUtils
-
Returns a
Predicate
of
Tuple2
that wraps a predicate of the component values of the tuple
- predicate(Predicate3<T1, T2, T3>) - Static method in class reactor.function.TupleUtils
-
Returns a
Predicate
of
Tuple3
that wraps a predicate of the component values of the tuple
- predicate(Predicate4<T1, T2, T3, T4>) - Static method in class reactor.function.TupleUtils
-
Returns a
Predicate
of
Tuple4
that wraps a predicate of the component values of the tuple
- predicate(Predicate5<T1, T2, T3, T4, T5>) - Static method in class reactor.function.TupleUtils
-
Returns a
Predicate
of
Tuple5
that wraps a predicate of the component values of the tuple
- predicate(Predicate6<T1, T2, T3, T4, T5, T6>) - Static method in class reactor.function.TupleUtils
-
Returns a
Predicate
of
Tuple6
that wraps a predicate of the component values of the tuple
- predicate(Predicate7<T1, T2, T3, T4, T5, T6, T7>) - Static method in class reactor.function.TupleUtils
-
Returns a
Predicate
of
Tuple7
that wraps a predicate of the component values of the tuple
- predicate(Predicate8<T1, T2, T3, T4, T5, T6, T7, T8>) - Static method in class reactor.function.TupleUtils
-
Returns a
Predicate
of
Tuple8
that wraps a predicate of the component values of the tuple
- Predicate3<T1,T2,T3> - Interface in reactor.function
-
Represents a predicate (boolean-valued function) of three arguments.
- Predicate4<T1,T2,T3,T4> - Interface in reactor.function
-
Represents a predicate (boolean-valued function) of four arguments.
- Predicate5<T1,T2,T3,T4,T5> - Interface in reactor.function
-
Represents a predicate (boolean-valued function) of five arguments.
- Predicate6<T1,T2,T3,T4,T5,T6> - Interface in reactor.function
-
Represents a predicate (boolean-valued function) of six arguments.
- Predicate7<T1,T2,T3,T4,T5,T6,T7> - Interface in reactor.function
-
Represents a predicate (boolean-valued function) of seven arguments.
- Predicate8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in reactor.function
-
Represents a predicate (boolean-valued function) of eight arguments.
- schedule(Runnable) - Method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
-
- schedule(Runnable, long, TimeUnit) - Method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
-
- schedule(Runnable) - Method in class reactor.swing.SwingScheduler
-
- schedule(Runnable, long, TimeUnit) - Method in class reactor.swing.SwingScheduler
-
- schedule(Runnable) - Method in class reactor.swing.SwtScheduler
-
- schedule(Runnable, long, TimeUnit) - Method in class reactor.swing.SwtScheduler
-
- schedulePeriodically(Runnable, long, long, TimeUnit) - Method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
-
- schedulePeriodically(Runnable, long, long, TimeUnit) - Method in class reactor.swing.SwingScheduler
-
- schedulePeriodically(Runnable, long, long, TimeUnit) - Method in class reactor.swing.SwtScheduler
-
- SchedulerClock - Class in reactor.scheduler.clock
-
- share(boolean) - Method in class reactor.extra.processor.TopicProcessor.Builder
-
Deprecated.
Configures sharing state for this builder.
- share(String, int) - Static method in class reactor.extra.processor.TopicProcessor
-
Deprecated.
Create a new shared TopicProcessor using the passed backlog size, with a blockingWait
Strategy and auto-cancellation.
- share(boolean) - Method in class reactor.extra.processor.WorkQueueProcessor.Builder
-
Deprecated.
Configures sharing state for this builder.
- share(String, int) - Static method in class reactor.extra.processor.WorkQueueProcessor
-
Deprecated.
Create a new shared WorkQueueProcessor using the passed buffer size, blockingWait
Strategy and auto-cancel.
- signalAllWhenBlocking() - Method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
Implementations should signal the waiting consumers that the cursor has advanced.
- signalSupplier(Supplier<T>) - Method in class reactor.extra.processor.TopicProcessor.Builder
-
Deprecated.
Configures a supplier of dispatched signals to preallocate in the ring buffer
- sleeping() - Static method in class reactor.extra.processor.WaitStrategy
-
Deprecated.
Yielding strategy that uses a Thread.sleep(1) for consumers waiting on a
barrier
after an initially spinning.
- subscribe(CoreSubscriber<? super E>) - Method in class reactor.extra.processor.TopicProcessor
-
Deprecated.
- subscribe(CoreSubscriber<? super E>) - Method in class reactor.extra.processor.WorkQueueProcessor
-
Deprecated.
- subscribe(CoreSubscriber<? super BigDecimal>) - Method in class reactor.math.MonoAverageBigDecimal
-
- subscribe(CoreSubscriber<? super BigInteger>) - Method in class reactor.math.MonoAverageBigInteger
-
- subscribe(CoreSubscriber<? super BigDecimal>) - Method in class reactor.math.MonoSumBigDecimal
-
- sumBigDecimal(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the
BigDecimal
sum of items in the source.
- sumBigDecimal(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the
BigDecimal
sum of items in the source, which are
mapped to numerical values using provided mapping.
- sumBigInteger(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the
BigInteger
sum of items in the source.
- sumBigInteger(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the
BigInteger
sum of items in the source, which are mapped to
numerical values using provided mapping.
- sumDouble(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the double sum of items in the source.
- sumDouble(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the double sum of items in the source, which are mapped to numerical values
using the provided mapping.
- sumFloat(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the float sum of items in the source.
- sumFloat(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the float sum of items in the source, which are mapped to numerical values
using the provided mapping.
- sumInt(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the integer sum of items in the source.
- sumInt(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the integer sum of items in the source, which are mapped to numerical values
using the provided mapping.
- sumLong(Publisher<? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the long sum of items in the source.
- sumLong(Publisher<T>, Function<? super T, ? extends Number>) - Static method in class reactor.math.MathFlux
-
Computes the long sum of items in the source, which are mapped to numerical values
using the provided mapping.
- SwingScheduler - Class in reactor.swing
-
Scheduler that runs tasks on Swing's event dispatch thread.
- SwtScheduler - Class in reactor.swing
-
Scheduler that runs tasks on Swt's event dispatch thread.