Skip navigation links
Reactor Addons: javadoc
A B C D E F G H I J L M N O P R S T W X Z 

A

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.
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
Set up the cache writer BiFunction to use to store the source data into the cache in case of cache miss.
andWriteWith(BiFunction<KEY, Signal<? extends VALUE>, Mono<Void>>) - Method in interface reactor.cache.CacheMono.MonoCacheBuilderCacheWriter
Set up the cache writer BiFunction to use to store the source data into the cache in case of cache miss.
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.
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.

B

Backoff - Interface in reactor.retry
Backoff function
backoff() - Method in class reactor.retry.DefaultContext
 
backoff(Backoff) - Method in class reactor.retry.DefaultRepeat
 
backoff(Backoff) - Method in class reactor.retry.DefaultRetry
 
backoff() - Method in interface reactor.retry.IterationContext
The backoff delay.
backoff(Backoff) - Method in interface reactor.retry.Repeat
Returns a repeat function with backoff delay.
backoff(Backoff) - Method in interface reactor.retry.Retry
Returns a retry function with backoff delay.
BackoffDelay - Class in reactor.retry
 
BackoffDelay(Duration) - Constructor for class reactor.retry.BackoffDelay
 
BackoffDelay(Duration, Duration, Duration) - Constructor for class reactor.retry.BackoffDelay
 
BooleanUtils - Class in reactor.bool
Functions to help compose results with Mono-wrapped boolean values.

C

CacheFlux - Class in reactor.cache
Opinionated caching helper that defines how to store and restore a Flux in an arbitrary cache abstraction.
CacheFlux() - Constructor for class reactor.cache.CacheFlux
 
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
Set up the cache writer BiFunction to use to store the source data into the cache in case of cache miss.
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() - Constructor for class reactor.cache.CacheMono
 
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
Set up the cache writer BiFunction to use to store the source data into the cache in case of cache miss.
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(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
Scheduler that utilizes a ForkJoinPool for workers and is suited for parallel work.
create(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Scheduler) - Static method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
Scheduler that utilizes a ForkJoinPool for workers and is suited for parallel work.
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
 

D

DefaultContext<T> - Class in reactor.retry
 
DefaultContext(T, long, BackoffDelay, long) - Constructor for class reactor.retry.DefaultContext
 
DefaultContext(T, long, BackoffDelay, Throwable) - Constructor for class reactor.retry.DefaultContext
 
DefaultRepeat<T> - Class in reactor.retry
 
DefaultRetry<T> - Class in reactor.retry
 
delay() - Method in class reactor.retry.BackoffDelay
 
dispose() - Method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
 
doOnRepeat(Consumer<? super RepeatContext<T>>) - Method in class reactor.retry.DefaultRepeat
 
doOnRepeat(Consumer<? super RepeatContext<T>>) - Method in interface reactor.retry.Repeat
Returns a repeat function that invokes the provided onRepeat callback before every repeat.
doOnRetry(Consumer<? super RetryContext<T>>) - Method in class reactor.retry.DefaultRetry
 
doOnRetry(Consumer<? super RetryContext<T>>) - Method in interface reactor.retry.Retry
Returns a retry function that invokes the provided onRetry callback before every retry.

E

equals(Object) - Method in class reactor.scheduler.clock.SchedulerClock
 
exception() - Method in class reactor.retry.DefaultContext
 
exception() - Method in interface reactor.retry.RetryContext
Returns the exception from the last iteration.
exponential(Duration, Duration, int, boolean) - Static method in interface reactor.retry.Backoff
Backoff function with exponential backoff delay.
exponentialBackoff(Duration, Duration) - Method in interface reactor.retry.Repeat
Returns a repeat function with exponential backoff delay.
exponentialBackoff(Duration, Duration) - Method in interface reactor.retry.Retry
Returns a retry function with exponential backoff delay.
exponentialBackoffWithJitter(Duration, Duration) - Method in interface reactor.retry.Repeat
Returns a repeat function with full jitter backoff strategy.
exponentialBackoffWithJitter(Duration, Duration) - Method in interface reactor.retry.Retry
Returns a retry function with full jitter backoff strategy.

F

fixed(Duration) - Static method in interface reactor.retry.Backoff
Backoff function with fixed backoff delay
fixedBackoff(Duration) - Method in interface reactor.retry.Repeat
Returns a repeat function with fixed backoff delay.
fixedBackoff(Duration) - Method in interface reactor.retry.Retry
Returns a retry function with fixed backoff delay.
ForkJoinPoolScheduler - Class in reactor.scheduler.forkjoin
 
from(Display) - Static method in class reactor.swing.SwtScheduler
 
function(BiFunction<T1, T2, R>) - Static method in class reactor.function.TupleUtils
Returns a Function of Tuple2 that wraps a function of the component values of the tuple
function(Function3<T1, T2, T3, R>) - Static method in class reactor.function.TupleUtils
Returns a Function of Tuple3 that wraps a function of the component values of the tuple
function(Function4<T1, T2, T3, T4, R>) - Static method in class reactor.function.TupleUtils
Returns a Function of Tuple4 that wraps a function of the component values of the tuple
function(Function5<T1, T2, T3, T4, T5, R>) - Static method in class reactor.function.TupleUtils
Returns a Function of Tuple5 that wraps a function of the component values of the tuple
function(Function6<T1, T2, T3, T4, T5, T6, R>) - Static method in class reactor.function.TupleUtils
Returns a Function of Tuple6 that wraps a function of the component values of the tuple
function(Function7<T1, T2, T3, T4, T5, T6, T7, R>) - Static method in class reactor.function.TupleUtils
Returns a Function of Tuple7 that wraps a function of the component values of the tuple
function(Function8<T1, T2, T3, T4, T5, T6, T7, T8, R>) - Static method in class reactor.function.TupleUtils
Returns a Function of Tuple8 that wraps a function of the component values of the tuple
Function3<T1,T2,T3,R> - Interface in reactor.function
Represents a function that accepts three arguments and produces a result.
Function4<T1,T2,T3,T4,R> - Interface in reactor.function
Represents a function that accepts four arguments and produces a result.
Function5<T1,T2,T3,T4,T5,R> - Interface in reactor.function
Represents a function that accepts five arguments and produces a result.
Function6<T1,T2,T3,T4,T5,T6,R> - Interface in reactor.function
Represents a function that accepts six arguments and produces a result.
Function7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in reactor.function
Represents a function that accepts seven arguments and produces a result.
Function8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in reactor.function
Represents a function that accepts eight arguments and produces a result.

G

getScheduler() - Method in class reactor.scheduler.clock.SchedulerClock
Return wrapped Scheduler instance
getZone() - Method in class reactor.scheduler.clock.SchedulerClock
 

H

hashCode() - Method in class reactor.scheduler.clock.SchedulerClock
 

I

instant() - Method in class reactor.scheduler.clock.SchedulerClock
Gets the current instant of the clock.
isDisposed() - Method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
 
iteration() - Method in class reactor.retry.DefaultContext
 
iteration() - Method in interface reactor.retry.IterationContext
The next iteration number.
IterationContext<T> - Interface in reactor.retry
Context provided to retry or repeat callbacks.

J

jitter(Jitter) - Method in class reactor.retry.DefaultRepeat
 
jitter(Jitter) - Method in class reactor.retry.DefaultRetry
 
Jitter - Interface in reactor.retry
Jitter function that is applied to the backoff delay.
jitter(Jitter) - Method in interface reactor.retry.Repeat
Returns a repeat function that applies jitter to the backoff delay.
jitter(Jitter) - Method in interface reactor.retry.Retry
Returns a retry function that applies jitter to the backoff delay.

L

lookup(Map<KEY, ? super List>, KEY, Class<VALUE>) - Static method in class reactor.cache.CacheFlux
Restore a Flux<VALUE> from the cache-map given a provided key.
lookup(Function<KEY, Mono<List<Signal<VALUE>>>>, KEY) - Static method in class reactor.cache.CacheFlux
Restore a Flux<VALUE> from the cache reader Function given a provided key.
lookup(Map<KEY, ? super Signal<? extends VALUE>>, KEY) - Static method in class reactor.cache.CacheMono
Restore a Mono<VALUE> from the cache-map given a provided key.
lookup(Map<KEY, ? super Signal<? extends VALUE>>, KEY, Class<VALUE>) - Static method in class reactor.cache.CacheMono
Restore a Mono<VALUE> from the cache-map given a provided key.
lookup(Function<KEY, Mono<Signal<? extends VALUE>>>, KEY) - Static method in class reactor.cache.CacheMono
Restore a Mono<VALUE> from the reader Function (see below) given a provided key.

M

MathFlux - Class in reactor.math
Mathematical utilities that compute sum, average, minimum or maximum values from numerical sources or sources that can be mapped to numerical values using custom mappings.
MathFlux() - Constructor for class reactor.math.MathFlux
 
max(Publisher<T>) - Static method in class reactor.math.MathFlux
Computes the maximum value of items in the source.
max(Publisher<T>, Comparator<? super T>) - Static method in class reactor.math.MathFlux
Computes the maximum value of items in the source.
maxDelay() - Method in class reactor.retry.BackoffDelay
 
millis() - Method in class reactor.scheduler.clock.SchedulerClock
 
min(Publisher<T>) - Static method in class reactor.math.MathFlux
Computes the minimum value of items in the source.
min(Publisher<T>, Comparator<? super T>) - Static method in class reactor.math.MathFlux
Computes the minimum value of items in the source.
minDelay() - Method in class reactor.retry.BackoffDelay
 

N

nand(Mono<Boolean>, Mono<Boolean>) - Static method in class reactor.bool.BooleanUtils
Two booleans, wrapped in Mono, combined with the NOT-AND (NAND) operator.
NO_JITTER - Static variable in interface reactor.retry.Jitter
 
noBackoff() - Method in interface reactor.retry.Repeat
Returns a repeat function with no backoff delay.
noBackoff() - Method in interface reactor.retry.Retry
Returns a retry function with no backoff delay.
noJitter() - Static method in interface reactor.retry.Jitter
Jitter function that is a no-op.
nor(Mono<Boolean>, Mono<Boolean>) - Static method in class reactor.bool.BooleanUtils
Two booleans, wrapped in Mono, combined with the NOT-OR (NOR) operator.
not(Mono<Boolean>) - Static method in class reactor.bool.BooleanUtils
A boolean, wrapped in a Mono, inverted by the NOT operator.

O

of(Scheduler) - Static method in class reactor.scheduler.clock.SchedulerClock
Create instance of SchedulerClock from given Scheduler and system default ZoneId.systemDefault()
of(Scheduler, ZoneId) - Static method in class reactor.scheduler.clock.SchedulerClock
Create instance of SchedulerClock from given Scheduler and ZoneId
onCacheMissResume(Flux<VALUE>) - Method in interface reactor.cache.CacheFlux.FluxCacheBuilderCacheMiss
Setup original source to fallback to in case of cache miss.
onCacheMissResume(Supplier<Flux<VALUE>>) - Method in interface reactor.cache.CacheFlux.FluxCacheBuilderCacheMiss
Setup original source to fallback to in case of cache miss, through a Supplier which allows lazy resolution of the source.
onCacheMissResume(Flux<VALUE>) - Method in interface reactor.cache.CacheFlux.FluxCacheBuilderMapMiss
Setup original source to fallback to in case of cache miss.
onCacheMissResume(Supplier<Flux<VALUE>>) - Method in interface reactor.cache.CacheFlux.FluxCacheBuilderMapMiss
Setup original source to fallback to in case of cache miss, through a Supplier which allows lazy resolution of the source.
onCacheMissResume(Mono<VALUE>) - Method in interface reactor.cache.CacheMono.MonoCacheBuilderCacheMiss
Setup original source to fallback to in case of cache miss.
onCacheMissResume(Supplier<Mono<VALUE>>) - Method in interface reactor.cache.CacheMono.MonoCacheBuilderCacheMiss
Setup original source to fallback to in case of cache miss, through a Supplier which allows lazy resolution of the source.
onCacheMissResume(Mono<VALUE>) - Method in interface reactor.cache.CacheMono.MonoCacheBuilderMapMiss
Setup original source to fallback to in case of cache miss.
onCacheMissResume(Supplier<Mono<VALUE>>) - Method in interface reactor.cache.CacheMono.MonoCacheBuilderMapMiss
Setup original source to fallback to in case of cache miss, through a Supplier which allows lazy resolution of the source.
once() - Static method in interface reactor.retry.Repeat
Repeat function that repeats once.
onHandleError(BiConsumer<Thread, ? super Throwable>) - Static method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
Define a hook that is executed when a Scheduler has handled an error.
onlyIf(Predicate<? super RepeatContext<T>>) - Static method in interface reactor.retry.Repeat
Repeat function that repeats only if the predicate returns true.
onlyIf(Predicate<? super RetryContext<T>>) - Static method in interface reactor.retry.Retry
Retry function that retries only if the predicate returns true, with no limit to the number of attempts.
or(Mono<Boolean>, Mono<Boolean>) - Static method in class reactor.bool.BooleanUtils
Two booleans, wrapped in Mono, combined with the OR operator.

P

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.

R

random() - Static method in interface reactor.retry.Jitter
Jitter function that applies a random jitter with a factor of 0.5, generating a backoff between [d - d*0.5; d + d*0.5] (but still within the limits of [BackoffDelay.minDelay(); BackoffDelay.maxDelay()].
random(double) - Static method in interface reactor.retry.Jitter
Jitter function that applies a random jitter with a provided [0; 1] factor (default 0.5), generating a backoff between [d - d*factor; d + d*factor] (but still within the limits of [BackoffDelay.minDelay(); BackoffDelay.maxDelay()].
RANDOM_JITTER - Static variable in interface reactor.retry.Jitter
 
randomBackoff(Duration, Duration) - Method in interface reactor.retry.Repeat
Returns a repeat function with random de-correlated jitter backoff strategy.
randomBackoff(Duration, Duration) - Method in interface reactor.retry.Retry
Returns a retry function with random de-correlated jitter backoff strategy.
reactor.bool - package reactor.bool
 
reactor.cache - package reactor.cache
Extra utilities around caching, providing a default go-to strategy on what to store in a cache.
reactor.function - package reactor.function
 
reactor.math - package reactor.math
 
reactor.retry - package reactor.retry
 
reactor.scheduler.clock - package reactor.scheduler.clock
 
reactor.scheduler.forkjoin - package reactor.scheduler.forkjoin
 
reactor.swing - package reactor.swing
 
Repeat<T> - Interface in reactor.retry
RepeatContext<T> - Interface in reactor.retry
Context provided to repeat predicate Repeat.onlyIf(java.util.function.Predicate) and the repeat callback Repeat.doOnRepeat(java.util.function.Consumer).
repeatMax(long) - Method in class reactor.retry.DefaultRepeat
 
repeatMax(long) - Method in interface reactor.retry.Repeat
Returns a repeat function that repeats at most n times.
resetOnHandleError() - Static method in class reactor.scheduler.forkjoin.ForkJoinPoolScheduler
Reset the ForkJoinPoolScheduler.onHandleError(BiConsumer) hook to the default no-op behavior.
Retry<T> - Interface in reactor.retry
Retry function that may be used with Flux.retryWhen(Function) and Mono.retryWhen(Function).
RetryContext<T> - Interface in reactor.retry
Context provided to retry predicate Retry.onlyIf(java.util.function.Predicate) and the retry callback Retry.doOnRetry(java.util.function.Consumer).
RetryExhaustedException - Exception in reactor.retry
Exception indicating that retries have been exhausted after Retry.timeout(java.time.Duration) or Retry#retryMax(int).
RetryExhaustedException() - Constructor for exception reactor.retry.RetryExhaustedException
 
RetryExhaustedException(String, Throwable, boolean, boolean) - Constructor for exception reactor.retry.RetryExhaustedException
 
RetryExhaustedException(String, Throwable) - Constructor for exception reactor.retry.RetryExhaustedException
 
RetryExhaustedException(String) - Constructor for exception reactor.retry.RetryExhaustedException
 
RetryExhaustedException(Throwable) - Constructor for exception reactor.retry.RetryExhaustedException
 
retryMax(long) - Method in class reactor.retry.DefaultRetry
 
retryMax(long) - Method in interface reactor.retry.Retry
Retry function that retries n times.
retryOnce() - Method in interface reactor.retry.Retry
Retry function that retries once.

S

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
Clock adapter around Scheduler.
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.

T

test(T1, T2, T3) - Method in interface reactor.function.Predicate3
Evaluates this predicate on the given arguments.
test(T1, T2, T3, T4) - Method in interface reactor.function.Predicate4
Evaluates this predicate on the given arguments.
test(T1, T2, T3, T4, T5) - Method in interface reactor.function.Predicate5
Evaluates this predicate on the given arguments.
test(T1, T2, T3, T4, T5, T6) - Method in interface reactor.function.Predicate6
Evaluates this predicate on the given arguments.
test(T1, T2, T3, T4, T5, T6, T7) - Method in interface reactor.function.Predicate7
Evaluates this predicate on the given arguments.
test(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface reactor.function.Predicate8
Evaluates this predicate on the given arguments.
timeout(Duration) - Method in class reactor.retry.DefaultRepeat
 
timeout(Duration) - Method in class reactor.retry.DefaultRetry
 
timeout(Duration) - Method in interface reactor.retry.Repeat
Returns a repeat function with timeout.
timeout(Duration) - Method in interface reactor.retry.Retry
Returns a retry function with timeout.
times(long) - Static method in interface reactor.retry.Repeat
Repeat function that repeats n times.
toString() - Method in class reactor.retry.BackoffDelay
 
toString() - Method in class reactor.retry.DefaultContext
 
toString() - Method in class reactor.retry.DefaultRepeat
 
toString() - Method in class reactor.retry.DefaultRetry
 
toString() - Method in class reactor.scheduler.clock.SchedulerClock
 
TupleUtils - Class in reactor.function
 

W

withApplicationContext(T) - Method in class reactor.retry.DefaultRepeat
 
withApplicationContext(T) - Method in class reactor.retry.DefaultRetry
 
withApplicationContext(T) - Method in interface reactor.retry.Repeat
Returns a repeat function with an application context that may be used to perform any rollbacks before a repeat.
withApplicationContext(T) - Method in interface reactor.retry.Retry
Returns a retry function with an application context that may be used to perform any rollbacks before a retry.
withBackoffScheduler(Scheduler) - Method in class reactor.retry.DefaultRepeat
 
withBackoffScheduler(Scheduler) - Method in class reactor.retry.DefaultRetry
 
withBackoffScheduler(Scheduler) - Method in interface reactor.retry.Repeat
Returns a repeat function that uses the scheduler provided for backoff delays.
withBackoffScheduler(Scheduler) - Method in interface reactor.retry.Retry
Returns a retry function that uses the scheduler provided for backoff delays.
withScheduler(Scheduler) - Method in class reactor.scheduler.clock.SchedulerClock
Builder method that returns new instance of SchedulerClock which is constructed from old ZoneId and passed Scheduler instance
withZone(ZoneId) - Method in class reactor.scheduler.clock.SchedulerClock
 

X

xor(Mono<Boolean>, Mono<Boolean>) - Static method in class reactor.bool.BooleanUtils
Two booleans, wrapped in Mono, combined with the exclusive-OR operator.

Z

zero() - Static method in interface reactor.retry.Backoff
Backoff function with no backoff delay
ZERO_BACKOFF - Static variable in interface reactor.retry.Backoff
 
A B C D E F G H I J L M N O P R S T W X Z 
Skip navigation links
Reactor Addons: javadoc