A B C D E F G H I J L M N O P R S T V W
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abortConditions - Variable in class dev.failsafe.RetryPolicyConfig
- abortHandler - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- abortIf(CheckedBiPredicate<R, ? extends Throwable>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Specifies that retries should be aborted if the
completionPredicate
matches the completion result. - abortIf(CheckedPredicate<R>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Specifies that retries should be aborted if the
resultPredicate
matches the result. - abortListener - Variable in class dev.failsafe.RetryPolicyConfig
- abortOn(CheckedPredicate<? extends Throwable>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Specifies that retries should be aborted if the
abortPredicate
matches the exception. - abortOn(Class<? extends Throwable>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Specifies when retries should be aborted.
- abortOn(Class<? extends Throwable>...) - Method in class dev.failsafe.RetryPolicyBuilder
-
Specifies when retries should be aborted.
- abortOn(List<Class<? extends Throwable>>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Specifies when retries should be aborted.
- abortWhen(R) - Method in class dev.failsafe.RetryPolicyBuilder
-
Specifies that retries should be aborted if the execution result matches the
result
. - accept(E) - Method in interface dev.failsafe.event.EventListener
- accept(T) - Method in interface dev.failsafe.function.CheckedConsumer
- acceptUnchecked(E) - Method in interface dev.failsafe.event.EventListener
-
Accepts an
event
and ignores any exceptions that result. - acquirePermit() - Method in interface dev.failsafe.Bulkhead
-
Attempts to acquire a permit to perform an execution against within the bulkhead, waiting until one is available or the thread is interrupted.
- acquirePermit() - Method in interface dev.failsafe.CircuitBreaker
-
Attempts to acquire a permit for the circuit breaker and throws
CircuitBreakerOpenException
if a permit could not be acquired. - acquirePermit() - Method in class dev.failsafe.internal.BulkheadImpl
- acquirePermit() - Method in interface dev.failsafe.RateLimiter
-
Attempts to acquire a permit to perform an execution against the rate limiter, waiting until one is available or the thread is interrupted.
- acquirePermit(Duration) - Method in interface dev.failsafe.Bulkhead
-
Attempts to acquire a permit to perform an execution within the bulkhead, waiting up to the
maxWaitTime
until one is available, else throwingBulkheadFullException
if a permit will not be available in time. - acquirePermit(Duration) - Method in interface dev.failsafe.RateLimiter
-
Attempts to acquire a permit to perform an execution against the rate limiter, waiting up to the
maxWaitTime
until one is available, else throwingRateLimitExceededException
if a permit will not be available in time. - acquirePermitAsync() - Method in class dev.failsafe.internal.BulkheadImpl
-
Returns a CompletableFuture that is completed when a permit is acquired.
- acquirePermits(int) - Method in class dev.failsafe.internal.RateLimiterImpl
- acquirePermits(int) - Method in interface dev.failsafe.RateLimiter
-
Attempts to acquire the requested
permits
to perform executions against the rate limiter, waiting until they are available or the thread is interrupted. - acquirePermits(int, Duration) - Method in interface dev.failsafe.RateLimiter
-
Attempts to acquire the requested
permits
to perform executions against the rate limiter, waiting up to themaxWaitTime
until they are available, else throwingRateLimitExceededException
if the permits will not be available in time. - acquirePermits(long, Duration) - Method in class dev.failsafe.internal.BurstyRateLimiterStats
- acquirePermits(long, Duration) - Method in class dev.failsafe.internal.RateLimiterStats
-
Eagerly acquires permits and returns the time in nanos that must be waited in order to use the permits, else returns
-1
if the wait time would exceed themaxWaitTime
. - acquirePermits(long, Duration) - Method in class dev.failsafe.internal.SmoothRateLimiterStats
- add() - Method in class dev.failsafe.internal.util.FutureLinkedList
-
Adds a new CompletableFuture to the list and returns it.
- add(long, long) - Static method in class dev.failsafe.internal.util.Maths
-
Returns the sum of
a
andb
elseLong.MAX_VALUE
if the sum would otherwise overflow. - add(TimedCircuitStats.Bucket) - Method in class dev.failsafe.internal.TimedCircuitStats.Stat
- adjustForBackoff(ExecutionContext<R>, long) - Method in class dev.failsafe.internal.RetryPolicyExecutor
- adjustForJitter(long) - Method in class dev.failsafe.internal.RetryPolicyExecutor
- adjustForMaxDuration(long, long) - Method in class dev.failsafe.internal.RetryPolicyExecutor
- allowsRetries() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns whether the policy config allows retries according to the configured
maxRetries
andmaxDuration
. - apply(Function<SyncExecutionInternal<R>, ExecutionResult<R>>, Scheduler) - Method in class dev.failsafe.internal.FallbackExecutor
-
Performs an execution by calling pre-execute else calling the supplier, applying a fallback if it fails, and calling post-execute.
- apply(Function<SyncExecutionInternal<R>, ExecutionResult<R>>, Scheduler) - Method in class dev.failsafe.internal.RetryPolicyExecutor
- apply(Function<SyncExecutionInternal<R>, ExecutionResult<R>>, Scheduler) - Method in class dev.failsafe.internal.TimeoutExecutor
-
Schedules a separate timeout call that fails with
TimeoutExceededException
if the policy's timeout is exceeded. - apply(Function<SyncExecutionInternal<R>, ExecutionResult<R>>, Scheduler) - Method in class dev.failsafe.spi.PolicyExecutor
-
Performs an execution by calling pre-execute else calling the supplier and doing a post-execute.
- apply(R, Throwable, ExecutionContext<R>) - Method in class dev.failsafe.internal.FallbackImpl
-
Returns the applied fallback result.
- apply(T) - Method in interface dev.failsafe.function.CheckedFunction
- applyAsync(Function<AsyncExecutionInternal<R>, CompletableFuture<ExecutionResult<R>>>, Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.internal.FallbackExecutor
-
Performs an async execution by calling pre-execute else calling the supplier and doing a post-execute.
- applyAsync(Function<AsyncExecutionInternal<R>, CompletableFuture<ExecutionResult<R>>>, Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.internal.RetryPolicyExecutor
- applyAsync(Function<AsyncExecutionInternal<R>, CompletableFuture<ExecutionResult<R>>>, Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.internal.TimeoutExecutor
-
Schedules a separate timeout call that blocks and fails with
TimeoutExceededException
if the policy's timeout is exceeded. - applyAsync(Function<AsyncExecutionInternal<R>, CompletableFuture<ExecutionResult<R>>>, Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.spi.PolicyExecutor
-
Performs an async execution by calling pre-execute else calling the supplier and doing a post-execute.
- applyStage(R, Throwable, ExecutionContext<R>) - Method in class dev.failsafe.internal.FallbackImpl
-
Returns a future applied fallback result.
- Assert - Class in dev.failsafe.internal.util
-
Assertion utilities.
- Assert() - Constructor for class dev.failsafe.internal.util.Assert
- assertFailureExecutionThreshold(int) - Method in class dev.failsafe.CircuitBreakerBuilder
- assertFailureThresholdingPeriod(Duration) - Method in class dev.failsafe.CircuitBreakerBuilder
- async - Variable in class dev.failsafe.FallbackConfig
- asyncExecution - Variable in class dev.failsafe.AsyncExecutionImpl
- AsyncExecution<R> - Interface in dev.failsafe
-
Allows asynchronous executions to record their results or complete an execution.
- AsyncExecutionImpl<R> - Class in dev.failsafe
-
AsyncExecution and AsyncExecutionInternal implementation.
- AsyncExecutionImpl(AsyncExecutionImpl<R>) - Constructor for class dev.failsafe.AsyncExecutionImpl
-
Create an async execution for a new attempt.
- AsyncExecutionImpl(List<Policy<R>>, Scheduler, FailsafeFuture<R>, boolean, Function<AsyncExecutionInternal<R>, CompletableFuture<ExecutionResult<R>>>) - Constructor for class dev.failsafe.AsyncExecutionImpl
- AsyncExecutionInternal<R> - Interface in dev.failsafe.spi
-
Internal async execution APIs.
- AsyncRunnable<R> - Interface in dev.failsafe.function
-
A Runnable that manually triggers asynchronous retries or completion via an asynchronous execution.
- AsyncSupplier<R,T> - Interface in dev.failsafe.function
-
A Supplier that manually triggers asynchronous retries or completion via an asynchronous execution.
- attemptRecorded - Variable in class dev.failsafe.ExecutionImpl
- attempts - Variable in class dev.failsafe.ExecutionImpl
- attemptStartTime - Variable in class dev.failsafe.ExecutionImpl
- availablePermits - Variable in class dev.failsafe.internal.BurstyRateLimiterStats
B
- bitSet - Variable in class dev.failsafe.internal.CountingCircuitStats
- breaker - Variable in class dev.failsafe.internal.CircuitState
- Bucket() - Constructor for class dev.failsafe.internal.TimedCircuitStats.Bucket
- buckets - Variable in class dev.failsafe.internal.TimedCircuitStats
- bucketSizeMillis - Variable in class dev.failsafe.internal.TimedCircuitStats
- build() - Method in class dev.failsafe.BulkheadBuilder
-
Builds a new
Bulkhead
using the builder's configuration. - build() - Method in class dev.failsafe.CircuitBreakerBuilder
-
Builds a new
CircuitBreaker
using the builder's configuration. - build() - Method in class dev.failsafe.FallbackBuilder
-
Builds a new
Fallback
using the builder's configuration. - build() - Method in class dev.failsafe.RateLimiterBuilder
-
Builds a new
RateLimiter
using the builder's configuration. - build() - Method in class dev.failsafe.RetryPolicyBuilder
-
Builds a new
RetryPolicy
using the builder's configuration. - build() - Method in class dev.failsafe.TimeoutBuilder
-
Builds a new
Timeout
using the builder's configuration. - builder() - Static method in interface dev.failsafe.CircuitBreaker
-
Creates a CircuitBreakerBuilder that by default will build a count based circuit breaker that opens after a
single failure
, closes after asingle success
, and has a 1 minutedelay
, unless configured otherwise. - builder() - Static method in interface dev.failsafe.RetryPolicy
-
Creates a RetryPolicyBuilder that by default will build a RetryPolicy that allows 3 execution attempts max with no delay, unless configured otherwise.
- builder(int) - Static method in interface dev.failsafe.Bulkhead
-
Returns a Bulkhead for the
maxConcurrency
that haszero wait
. - builder(BulkheadConfig<R>) - Static method in interface dev.failsafe.Bulkhead
-
Creates a new BulkheadBuilder that will be based on the
config
. - builder(CircuitBreakerConfig<R>) - Static method in interface dev.failsafe.CircuitBreaker
-
Creates a new CircuitBreakerBuilder that will be based on the
config
. - builder(FallbackConfig<R>) - Static method in interface dev.failsafe.Fallback
-
Creates a new FallbackBuilder that will be based on the
config
. - builder(CheckedConsumer<ExecutionAttemptedEvent<? extends R>>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - builder(CheckedFunction<ExecutionAttemptedEvent<? extends R>, ? extends R>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - builder(CheckedRunnable) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - builder(CheckedSupplier<? extends R>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - builder(RateLimiterConfig<R>) - Static method in interface dev.failsafe.RateLimiter
-
Creates a new RateLimiterBuilder that will be based on the
config
. - builder(RetryPolicyConfig<R>) - Static method in interface dev.failsafe.RetryPolicy
-
Creates a new RetryPolicyBuilder that will be based on the
config
. - builder(TimeoutConfig<R>) - Static method in interface dev.failsafe.Timeout
-
Creates a new TimeoutBuilder that will be based on the
config
. - builder(Duration) - Static method in interface dev.failsafe.Timeout
- builder(R) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallbackResult
to be provided if execution fails. - builderOfException(CheckedFunction<ExecutionAttemptedEvent<? extends R>, ? extends Exception>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails and allows an alternative exception to be supplied instead. - builderOfStage(CheckedFunction<ExecutionAttemptedEvent<? extends R>, ? extends CompletionStage<R>>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - builderOfStage(CheckedSupplier<? extends CompletionStage<R>>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - bulkhead - Variable in exception dev.failsafe.BulkheadFullException
- bulkhead - Variable in class dev.failsafe.internal.BulkheadExecutor
- Bulkhead<R> - Interface in dev.failsafe
-
A bulkhead allows you to restrict concurrent executions as a way of preventing system overload.
- BulkheadBuilder<R> - Class in dev.failsafe
-
Builds
Bulkhead
instances. - BulkheadBuilder(int) - Constructor for class dev.failsafe.BulkheadBuilder
- BulkheadBuilder(BulkheadConfig<R>) - Constructor for class dev.failsafe.BulkheadBuilder
- BulkheadConfig<R> - Class in dev.failsafe
-
Configuration for a
Bulkhead
. - BulkheadConfig(int) - Constructor for class dev.failsafe.BulkheadConfig
- BulkheadConfig(BulkheadConfig<R>) - Constructor for class dev.failsafe.BulkheadConfig
- BulkheadExecutor<R> - Class in dev.failsafe.internal
-
A PolicyExecutor that handles failures according to a
Bulkhead
. - BulkheadExecutor(BulkheadImpl<R>, int) - Constructor for class dev.failsafe.internal.BulkheadExecutor
- BulkheadFullException - Exception in dev.failsafe
-
Thrown when an execution is attempted against a
Bulkhead
that is full. - BulkheadFullException(Bulkhead<?>) - Constructor for exception dev.failsafe.BulkheadFullException
- BulkheadImpl<R> - Class in dev.failsafe.internal
-
A Bulkhead implementation that supports sync and async waiting.
- BulkheadImpl(BulkheadConfig<R>) - Constructor for class dev.failsafe.internal.BulkheadImpl
- burstyBuilder(long, Duration) - Static method in interface dev.failsafe.RateLimiter
- BurstyRateLimiterStats - Class in dev.failsafe.internal
-
A rate limiter implementation that allows bursts of executions, up to the max permits per period.
- BurstyRateLimiterStats(RateLimiterConfig<?>, RateLimiterStats.Stopwatch) - Constructor for class dev.failsafe.internal.BurstyRateLimiterStats
C
- call - Variable in class dev.failsafe.SyncExecutionImpl
- call(ContextualSupplier<T, T>) - Method in class dev.failsafe.FailsafeExecutor
-
Calls the
innerSupplier
synchronously, handling results according to the configured policies. - Call<R> - Interface in dev.failsafe
-
A call that can perform Failsafe executions and can be cancelled.
- callAsync(Function<FailsafeFuture<T>, Function<AsyncExecutionInternal<T>, CompletableFuture<ExecutionResult<T>>>>, boolean) - Method in class dev.failsafe.FailsafeExecutor
-
Calls the asynchronous
innerFn
via the configured Scheduler, handling results according to the configured policies. - CallImpl<R> - Class in dev.failsafe
-
A call implementation that delegates to an execution.
- CallImpl() - Constructor for class dev.failsafe.CallImpl
- callSync(ContextualSupplier<T, T>) - Method in class dev.failsafe.FailsafeExecutor
-
Returns a Call that calls the
innerSupplier
synchronously, handling results according to the configured policies. - cancel() - Method in class dev.failsafe.ExecutionImpl
-
Called indirectly by users.
- cancel() - Method in interface dev.failsafe.spi.ExecutionInternal
-
Marks the execution as having been cancelled externally, which will cancel pending executions of all policies.
- cancel(boolean) - Method in interface dev.failsafe.Call
-
Cancels a synchronous execution and calls the most recent
cancelCallback
that was registered. - cancel(boolean) - Method in class dev.failsafe.CallImpl
- cancel(boolean) - Method in class dev.failsafe.internal.util.DelegatingScheduler.ScheduledCompletableFuture
- cancel(boolean) - Method in class dev.failsafe.spi.DefaultScheduledFuture
- cancel(boolean) - Method in class dev.failsafe.spi.FailsafeFuture
-
Cancels the future along with any dependencies.
- cancel(PolicyExecutor<R>) - Method in class dev.failsafe.ExecutionImpl
-
Called by policies.
- cancel(PolicyExecutor<R>) - Method in interface dev.failsafe.spi.ExecutionInternal
-
Marks the execution as having been cancelled by the
policyExecutor
, which will also cancel pending executions of any inner policies of thepolicyExecutor
. - cancelCallback - Variable in class dev.failsafe.ExecutionImpl
- cancelDependencies(PolicyExecutor<R>, boolean, ExecutionResult<R>) - Method in class dev.failsafe.spi.FailsafeFuture
-
Applies any
cancel functions
with thecancelResult
for PolicyExecutors whose policyIndex is < the policyIndex of thecancellingPolicyExecutor
. - cancelFunctions - Variable in class dev.failsafe.spi.FailsafeFuture
- cancelledIndex - Variable in class dev.failsafe.ExecutionImpl
- cancelledWithInterrupt - Variable in class dev.failsafe.spi.FailsafeFuture
- canInterrupt - Variable in class dev.failsafe.TimeoutConfig
- canInterrupt() - Method in class dev.failsafe.TimeoutConfig
-
Returns whether the policy can interrupt an execution if the timeout is exceeded.
- capacityFor(CircuitBreaker<?>) - Static method in class dev.failsafe.internal.ClosedState
-
Returns the capacity of the breaker in the closed state.
- capacityFor(CircuitBreaker<?>) - Static method in class dev.failsafe.internal.HalfOpenState
-
Returns the capacity of the breaker in the half-open state.
- CheckedBiPredicate<T,U> - Interface in dev.failsafe.function
-
A BiPredicate that throws checked exceptions.
- CheckedConsumer<T> - Interface in dev.failsafe.function
-
A Consumer that throws checked exceptions.
- CheckedFunction<T,R> - Interface in dev.failsafe.function
-
A Function that throws checked exceptions.
- CheckedPredicate<T> - Interface in dev.failsafe.function
-
A Predicate that throws checked exceptions.
- CheckedRunnable - Interface in dev.failsafe.function
-
A Runnable that throws checked exceptions.
- CheckedSupplier<T> - Interface in dev.failsafe.function
-
A Supplier that throws checked exceptions.
- checkThreshold(ExecutionContext<R>) - Method in class dev.failsafe.internal.CircuitState
- checkThreshold(ExecutionContext<R>) - Method in class dev.failsafe.internal.ClosedState
-
Checks to see if the executions and failure thresholds have been exceeded, opening the circuit if so.
- checkThreshold(ExecutionContext<R>) - Method in class dev.failsafe.internal.HalfOpenState
-
Checks to determine if a threshold has been met and the circuit should be opened or closed.
- circuitBreaker - Variable in exception dev.failsafe.CircuitBreakerOpenException
- circuitBreaker - Variable in class dev.failsafe.internal.CircuitBreakerExecutor
- CircuitBreaker<R> - Interface in dev.failsafe
-
A circuit breaker temporarily blocks execution when a configured number of failures are exceeded.
- CircuitBreaker.State - Enum in dev.failsafe
-
The state of the circuit.
- CircuitBreakerBuilder<R> - Class in dev.failsafe
-
Builds
CircuitBreaker
instances. - CircuitBreakerBuilder() - Constructor for class dev.failsafe.CircuitBreakerBuilder
- CircuitBreakerBuilder(CircuitBreakerConfig<R>) - Constructor for class dev.failsafe.CircuitBreakerBuilder
- CircuitBreakerConfig<R> - Class in dev.failsafe
-
Configuration for a
CircuitBreaker
. - CircuitBreakerConfig() - Constructor for class dev.failsafe.CircuitBreakerConfig
- CircuitBreakerConfig(CircuitBreakerConfig<R>) - Constructor for class dev.failsafe.CircuitBreakerConfig
- CircuitBreakerExecutor<R> - Class in dev.failsafe.internal
-
A PolicyExecutor that handles failures according to a
CircuitBreaker
. - CircuitBreakerExecutor(CircuitBreakerImpl<R>, int) - Constructor for class dev.failsafe.internal.CircuitBreakerExecutor
- CircuitBreakerImpl<R> - Class in dev.failsafe.internal
-
A
CircuitBreaker
implementation. - CircuitBreakerImpl(CircuitBreakerConfig<R>) - Constructor for class dev.failsafe.internal.CircuitBreakerImpl
- CircuitBreakerOpenException - Exception in dev.failsafe
-
Thrown when an execution is attempted against a
CircuitBreaker
that is open. - CircuitBreakerOpenException(CircuitBreaker<?>) - Constructor for exception dev.failsafe.CircuitBreakerOpenException
- CircuitBreakerStateChangedEvent - Class in dev.failsafe.event
-
Indicates a circuit breaker's state changed.
- CircuitBreakerStateChangedEvent(CircuitBreaker.State) - Constructor for class dev.failsafe.event.CircuitBreakerStateChangedEvent
- CircuitState<R> - Class in dev.failsafe.internal
-
The state of a circuit.
- CircuitState(CircuitBreakerImpl<R>, CircuitStats) - Constructor for class dev.failsafe.internal.CircuitState
- CircuitStats - Interface in dev.failsafe.internal
-
Stats for a circuit breaker.
- clock - Variable in class dev.failsafe.internal.TimedCircuitStats
- Clock() - Constructor for class dev.failsafe.internal.TimedCircuitStats.Clock
- close() - Method in interface dev.failsafe.CircuitBreaker
-
Closes the circuit.
- close() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- CLOSED - dev.failsafe.CircuitBreaker.State
-
The circuit is closed and fully functional, allowing executions to occur.
- ClosedState<R> - Class in dev.failsafe.internal
- ClosedState(CircuitBreakerImpl<R>) - Constructor for class dev.failsafe.internal.ClosedState
- closeListener - Variable in class dev.failsafe.CircuitBreakerConfig
- compareTo(Delayed) - Method in class dev.failsafe.internal.util.DelegatingScheduler.ScheduledCompletableFuture
- compareTo(Delayed) - Method in class dev.failsafe.spi.DefaultScheduledFuture
- complete - Variable in class dev.failsafe.spi.ExecutionResult
-
Whether a policy has completed handling of the execution
- complete() - Method in interface dev.failsafe.AsyncExecution
-
Completes the execution and the associated
CompletableFuture
. - complete() - Method in class dev.failsafe.AsyncExecutionImpl
- complete() - Method in interface dev.failsafe.Execution
-
Records and completes the execution successfully.
- complete() - Method in class dev.failsafe.SyncExecutionImpl
- complete(ExecutionResult<R>, Throwable) - Method in class dev.failsafe.AsyncExecutionImpl
- complete(R) - Method in class dev.failsafe.spi.FailsafeFuture
-
If not already completed, completes the future with the
value
, calling the complete and success handlers. - completed - Variable in class dev.failsafe.ExecutionImpl
- completeExceptionally(Throwable) - Method in class dev.failsafe.spi.FailsafeFuture
-
If not already completed, completes the future with the
exception
, calling the complete and failure handlers. - completeHandler - Variable in class dev.failsafe.FailsafeExecutor
- completeResult(ExecutionResult<R>) - Method in class dev.failsafe.spi.FailsafeFuture
-
Completes the execution with the
result
and calls the completion handler. - completionHandler - Variable in class dev.failsafe.FailsafeExecutor
- completionHandler - Variable in class dev.failsafe.spi.FailsafeFuture
- compose(P) - Method in class dev.failsafe.FailsafeExecutor
-
Returns a new
FailsafeExecutor
that composes the currently configured policies around the giveninnerPolicy
. - computeDelay(ExecutionContext<R>) - Method in interface dev.failsafe.spi.DelayablePolicy
-
Returns a computed delay for the
result
andcontext
elsenull
if no delay function is configured or the computed delay is invalid. - config - Variable in class dev.failsafe.internal.BulkheadImpl
- config - Variable in class dev.failsafe.internal.CircuitBreakerImpl
- config - Variable in class dev.failsafe.internal.CircuitState
- config - Variable in class dev.failsafe.internal.FallbackExecutor
- config - Variable in class dev.failsafe.internal.FallbackImpl
- config - Variable in class dev.failsafe.internal.RateLimiterImpl
- config - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- config - Variable in class dev.failsafe.internal.RetryPolicyImpl
- config - Variable in class dev.failsafe.internal.TimeoutExecutor
- config - Variable in class dev.failsafe.internal.TimeoutImpl
- config - Variable in class dev.failsafe.PolicyBuilder
- context - Variable in class dev.failsafe.event.ExecutionEvent
- ContextualRunnable<R> - Interface in dev.failsafe.function
-
A Runnable that provides execution context.
- ContextualSupplier<R,T> - Interface in dev.failsafe.function
-
A Supplier that provides execution context.
- copy() - Method in class dev.failsafe.AsyncExecutionImpl
- copy() - Method in interface dev.failsafe.spi.AsyncExecutionInternal
-
Returns a new copy of the AsyncExecutionInternal.
- copy() - Method in interface dev.failsafe.spi.SyncExecutionInternal
-
Returns a new copy of the SyncExecutionInternal if it is not standalone, else returns
this
since standalone executions are referenced externally and cannot be replaced. - copy() - Method in class dev.failsafe.SyncExecutionImpl
- copyExecutions(CircuitStats) - Method in interface dev.failsafe.internal.CircuitStats
- copyFrom(TimedCircuitStats.Bucket) - Method in class dev.failsafe.internal.TimedCircuitStats.Bucket
- copyStats(CircuitStats) - Method in class dev.failsafe.internal.CountingCircuitStats
-
Copies the most recent stats from the
oldStats
into this in order from oldest to newest. - copyStats(CircuitStats) - Method in class dev.failsafe.internal.TimedCircuitStats
-
Copies the most recent stats from the
oldStats
into this in order from oldest to newest and orders buckets from oldest to newest, with uninitialized buckets counting as oldest. - CountingCircuitStats - Class in dev.failsafe.internal
-
A CircuitStats implementation that counts execution results using a BitSet.
- CountingCircuitStats(int, CircuitStats) - Constructor for class dev.failsafe.internal.CountingCircuitStats
- create(CircuitBreaker<?>, int, boolean, CircuitStats) - Static method in interface dev.failsafe.internal.CircuitStats
- currentIndex - Variable in class dev.failsafe.internal.CountingCircuitStats
-
Index to write next entry to
- currentIndex - Variable in class dev.failsafe.internal.TimedCircuitStats
- currentPeriod - Variable in class dev.failsafe.internal.BurstyRateLimiterStats
- currentTimeMillis() - Method in class dev.failsafe.internal.TimedCircuitStats.Clock
D
- DEFAULT - Static variable in interface dev.failsafe.spi.Scheduler
-
The default scheduler used by Failsafe if no other scheduler or
ScheduledExecutorService
is configured for an execution. - DEFAULT_BUCKET_COUNT - Static variable in class dev.failsafe.internal.TimedCircuitStats
- DEFAULT_MAX_RETRIES - Static variable in class dev.failsafe.RetryPolicyBuilder
- DefaultCircuitStats - Class in dev.failsafe.internal
-
A default CircuitStats implementation that tracks a single execution result.
- DefaultCircuitStats() - Constructor for class dev.failsafe.internal.DefaultCircuitStats
- DefaultScheduledFuture<R> - Class in dev.failsafe.spi
-
A default ScheduledFuture implementation.
- DefaultScheduledFuture() - Constructor for class dev.failsafe.spi.DefaultScheduledFuture
- delay - Variable in class dev.failsafe.DelayablePolicyConfig
- delay - Variable in class dev.failsafe.event.ExecutionScheduledEvent
- DelayablePolicy<R> - Interface in dev.failsafe.spi
-
A policy that can be delayed between executions.
- DelayablePolicyBuilder<S,C extends DelayablePolicyConfig<R>,R> - Class in dev.failsafe
-
A builder of policies that can be delayed between executions.
- DelayablePolicyBuilder(C) - Constructor for class dev.failsafe.DelayablePolicyBuilder
- DelayablePolicyConfig<R> - Class in dev.failsafe
-
Configuration for policies that can delay between executions.
- DelayablePolicyConfig() - Constructor for class dev.failsafe.DelayablePolicyConfig
- DelayablePolicyConfig(DelayablePolicyConfig<R>) - Constructor for class dev.failsafe.DelayablePolicyConfig
- delayer() - Static method in class dev.failsafe.internal.util.DelegatingScheduler
- DELAYER - Static variable in class dev.failsafe.internal.util.DelegatingScheduler
- DelayerThreadFactory() - Constructor for class dev.failsafe.internal.util.DelegatingScheduler.DelayerThreadFactory
- delayException - Variable in class dev.failsafe.DelayablePolicyConfig
- delayFactor - Variable in class dev.failsafe.RetryPolicyConfig
- delayFn - Variable in class dev.failsafe.DelayablePolicyConfig
- delayMax - Variable in class dev.failsafe.RetryPolicyConfig
- delayMin - Variable in class dev.failsafe.RetryPolicyConfig
- delayNanos - Variable in class dev.failsafe.internal.OpenState
- delayNanos - Variable in class dev.failsafe.spi.ExecutionResult
-
The amount of time to wait prior to the next execution, according to the policy
- delayNanos - Variable in class dev.failsafe.SyncExecutionImpl
- delayResult - Variable in class dev.failsafe.DelayablePolicyConfig
- delegate - Variable in class dev.failsafe.internal.util.DelegatingScheduler.ScheduledCompletableFuture
- DelegatingScheduler - Class in dev.failsafe.internal.util
-
A
Scheduler
implementation that schedules delays on an internal, common ScheduledExecutorService and executes tasks on either a providedExecutorService
,ForkJoinPool.commonPool()
, or an internalForkJoinPool
instance. - DelegatingScheduler() - Constructor for class dev.failsafe.internal.util.DelegatingScheduler
- DelegatingScheduler(ExecutorService) - Constructor for class dev.failsafe.internal.util.DelegatingScheduler
- DelegatingScheduler.DelayerThreadFactory - Class in dev.failsafe.internal.util
- DelegatingScheduler.ScheduledCompletableFuture<V> - Class in dev.failsafe.internal.util
- dev.failsafe - package dev.failsafe
-
APIs for performing failsafe executions.
- dev.failsafe.event - package dev.failsafe.event
-
Event listener types.
- dev.failsafe.function - package dev.failsafe.function
-
Functional interface types.
- dev.failsafe.internal - package dev.failsafe.internal
- dev.failsafe.internal.util - package dev.failsafe.internal.util
- dev.failsafe.spi - package dev.failsafe.spi
-
The Failsafe Service Provider Interface (SPI).
- Durations - Class in dev.failsafe.internal.util
-
Duration and long utilities.
- Durations() - Constructor for class dev.failsafe.internal.util.Durations
E
- elapsedNanos() - Method in class dev.failsafe.internal.RateLimiterStats.Stopwatch
- equals(Object) - Method in class dev.failsafe.spi.ExecutionResult
- EventHandler<R> - Interface in dev.failsafe.internal
-
Internal handling of events.
- EventListener<E> - Interface in dev.failsafe.event
-
Listens for events.
- exceedsMaxWaitTime(long, Duration) - Method in class dev.failsafe.internal.RateLimiterStats
-
Returns whether the
waitNanos
would exceed themaxWaitTime
, elsefalse
ifmaxWaitTime
is null. - exception - Variable in class dev.failsafe.event.ExecutionAttemptedEvent
- exception - Variable in class dev.failsafe.event.ExecutionCompletedEvent
- exception - Variable in class dev.failsafe.event.ExecutionScheduledEvent
- exception - Variable in class dev.failsafe.spi.ExecutionResult
-
The execution exception, if any
- exception(Throwable) - Static method in class dev.failsafe.spi.ExecutionResult
-
Returns an ExecutionResult with the
exception
set,complete
true andsuccess
false. - exceptionsChecked - Variable in class dev.failsafe.FailurePolicyConfig
-
Indicates whether exceptions are checked by a configured failure condition
- execute() - Method in interface dev.failsafe.Call
-
Executes the call until a successful result is returned or the configured policies are exceeded.
- execute() - Method in class dev.failsafe.CallImpl
- executeAsync() - Method in class dev.failsafe.AsyncExecutionImpl
-
Performs an asynchronous execution.
- executeSync() - Method in class dev.failsafe.SyncExecutionImpl
-
Performs a synchronous execution.
- execution - Variable in class dev.failsafe.CallImpl
- Execution<R> - Interface in dev.failsafe
-
Tracks synchronous executions and handles failures according to one or more
policies
. - ExecutionAttemptedEvent<R> - Class in dev.failsafe.event
-
Indicates an execution was attempted.
- ExecutionAttemptedEvent(R, Throwable, ExecutionContext<R>) - Constructor for class dev.failsafe.event.ExecutionAttemptedEvent
- ExecutionCompletedEvent<R> - Class in dev.failsafe.event
-
Indicates an execution was completed or cancelled.
- ExecutionCompletedEvent(R, Throwable, ExecutionContext<R>) - Constructor for class dev.failsafe.event.ExecutionCompletedEvent
- ExecutionContext<R> - Interface in dev.failsafe
-
Contextual execution information.
- ExecutionEvent - Class in dev.failsafe.event
-
Encapsulates information about a Failsafe execution.
- ExecutionEvent(ExecutionContext<?>) - Constructor for class dev.failsafe.event.ExecutionEvent
- ExecutionImpl<R> - Class in dev.failsafe
-
Execution and ExecutionInternal implementation.
- ExecutionImpl(ExecutionImpl<R>) - Constructor for class dev.failsafe.ExecutionImpl
-
Create an execution for a new attempt.
- ExecutionImpl(ExecutionResult<R>) - Constructor for class dev.failsafe.ExecutionImpl
-
Used for testing purposes only
- ExecutionImpl(List<? extends Policy<R>>) - Constructor for class dev.failsafe.ExecutionImpl
-
Creates a new execution for the
policies
. - ExecutionInternal<R> - Interface in dev.failsafe.spi
-
Internal execution APIs.
- ExecutionResult<R> - Class in dev.failsafe.spi
-
This class represents the internal result of an execution attempt for zero or more policies, before or after the policy has handled the result.
- ExecutionResult(R, Throwable) - Constructor for class dev.failsafe.spi.ExecutionResult
-
Records an initial execution result with
complete
true andsuccess
set to true ifexception
is not null. - ExecutionResult(R, Throwable, boolean, long, boolean, boolean, Boolean) - Constructor for class dev.failsafe.spi.ExecutionResult
- executions - Variable in class dev.failsafe.ExecutionImpl
- ExecutionScheduledEvent<R> - Class in dev.failsafe.event
-
Indicates an execution was scheduled.
- ExecutionScheduledEvent(R, Throwable, Duration, ExecutionContext<R>) - Constructor for class dev.failsafe.event.ExecutionScheduledEvent
- executionThread - Variable in class dev.failsafe.SyncExecutionImpl
- executor - Variable in class dev.failsafe.FailsafeExecutor
- executor - Variable in class dev.failsafe.SyncExecutionImpl
- executorService - Variable in class dev.failsafe.internal.util.DelegatingScheduler
- executorService() - Method in class dev.failsafe.internal.util.DelegatingScheduler
F
- failedAttemptHandler - Variable in class dev.failsafe.internal.FallbackExecutor
- failedAttemptHandler - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- failedAttemptListener - Variable in class dev.failsafe.FallbackConfig
- failedAttemptListener - Variable in class dev.failsafe.RetryPolicyConfig
- failedAttempts - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- Failsafe - Class in dev.failsafe
-
Simple, sophisticated failure handling.
- Failsafe() - Constructor for class dev.failsafe.Failsafe
- FailsafeException - Exception in dev.failsafe
-
Thrown when a synchronous Failsafe execution fails with an
Exception
, wrapping the underlying exception. - FailsafeException() - Constructor for exception dev.failsafe.FailsafeException
- FailsafeException(Throwable) - Constructor for exception dev.failsafe.FailsafeException
- FailsafeExecutor<R> - Class in dev.failsafe
-
An executor that handles failures according to configured
policies
. - FailsafeExecutor(List<? extends Policy<R>>) - Constructor for class dev.failsafe.FailsafeExecutor
- FailsafeFuture<R> - Class in dev.failsafe.spi
-
A CompletableFuture implementation that propagates cancellations and calls completion handlers.
- FailsafeFuture(BiConsumer<ExecutionResult<R>, ExecutionContext<R>>) - Constructor for class dev.failsafe.spi.FailsafeFuture
- failureConditions - Variable in class dev.failsafe.FailurePolicyConfig
-
Conditions that determine whether an execution is a failure
- failureExecutionThreshold - Variable in class dev.failsafe.CircuitBreakerConfig
- failureHandler - Variable in class dev.failsafe.FailsafeExecutor
- failureHandler - Variable in class dev.failsafe.spi.PolicyExecutor
- failureListener - Variable in class dev.failsafe.PolicyConfig
- failurePolicy - Variable in class dev.failsafe.spi.PolicyExecutor
-
Optional APIs for policies that support them
- FailurePolicy<R> - Interface in dev.failsafe.spi
-
A policy that can handle specifically configured failures.
- FailurePolicyBuilder<S,C extends FailurePolicyConfig<R>,R> - Class in dev.failsafe
-
A Policy that allows configurable conditions to determine whether an execution is a failure.
- FailurePolicyBuilder(C) - Constructor for class dev.failsafe.FailurePolicyBuilder
- FailurePolicyConfig<R> - Class in dev.failsafe
-
Configuration for policies that handle specific failures and conditions.
- FailurePolicyConfig() - Constructor for class dev.failsafe.FailurePolicyConfig
- FailurePolicyConfig(FailurePolicyConfig<R>) - Constructor for class dev.failsafe.FailurePolicyConfig
- failurePredicateFor(CheckedPredicate<? extends Throwable>) - Static method in class dev.failsafe.FailurePolicyBuilder
-
Returns a predicate that evaluates the
failurePredicate
against a failure. - failurePredicateFor(List<Class<? extends Throwable>>) - Static method in class dev.failsafe.FailurePolicyBuilder
-
Returns a predicate that returns whether any of the
failures
are assignable from an execution failure. - failureRateThreshold - Variable in class dev.failsafe.CircuitBreakerConfig
- failures - Variable in class dev.failsafe.internal.CountingCircuitStats
- failures - Variable in class dev.failsafe.internal.TimedCircuitStats.Stat
- failureThreshold - Variable in class dev.failsafe.CircuitBreakerConfig
- failureThresholdingCapacity - Variable in class dev.failsafe.CircuitBreakerConfig
- failureThresholdingPeriod - Variable in class dev.failsafe.CircuitBreakerConfig
- fallback - Variable in class dev.failsafe.FallbackConfig
- fallback - Variable in class dev.failsafe.internal.FallbackExecutor
- Fallback<R> - Interface in dev.failsafe
-
A Policy that handles failures using a fallback function or result.
- FallbackBuilder<R> - Class in dev.failsafe
-
Builds
Fallback
instances. - FallbackBuilder(FallbackConfig<R>) - Constructor for class dev.failsafe.FallbackBuilder
- FallbackBuilder(CheckedFunction<ExecutionAttemptedEvent<R>, R>, CheckedFunction<ExecutionAttemptedEvent<R>, CompletableFuture<R>>) - Constructor for class dev.failsafe.FallbackBuilder
- FallbackConfig<R> - Class in dev.failsafe
-
Configuration for a
Fallback
. - FallbackConfig() - Constructor for class dev.failsafe.FallbackConfig
- FallbackConfig(FallbackConfig<R>) - Constructor for class dev.failsafe.FallbackConfig
- FallbackConfig(CheckedFunction<ExecutionAttemptedEvent<R>, R>, CheckedFunction<ExecutionAttemptedEvent<R>, CompletableFuture<R>>) - Constructor for class dev.failsafe.FallbackConfig
- FallbackExecutor<R> - Class in dev.failsafe.internal
-
A PolicyExecutor that handles failures according to a
Fallback
. - FallbackExecutor(FallbackImpl<R>, int) - Constructor for class dev.failsafe.internal.FallbackExecutor
- FallbackImpl<R> - Class in dev.failsafe.internal
-
A
Fallback
implementation. - FallbackImpl(FallbackConfig<R>) - Constructor for class dev.failsafe.internal.FallbackImpl
- fallbackStage - Variable in class dev.failsafe.FallbackConfig
- FORK_JOIN_POOL - Static variable in class dev.failsafe.internal.util.DelegatingScheduler
- forkJoinPoolThread - Variable in class dev.failsafe.internal.util.DelegatingScheduler.ScheduledCompletableFuture
- Functions - Class in dev.failsafe
-
Utilities for creating and applying Failsafe executable functions.
- Functions() - Constructor for class dev.failsafe.Functions
- future - Variable in class dev.failsafe.AsyncExecutionImpl
- future - Variable in class dev.failsafe.internal.util.FutureLinkedList.Node
- FutureLinkedList - Class in dev.failsafe.internal.util
-
A LinkedList of CompletableFutures that removes a future from the list when it's completed.
- FutureLinkedList() - Constructor for class dev.failsafe.internal.util.FutureLinkedList
- FutureLinkedList.Node - Class in dev.failsafe.internal.util
- futures - Variable in class dev.failsafe.internal.BulkheadImpl
G
- get() - Method in interface dev.failsafe.function.CheckedSupplier
- get() - Method in class dev.failsafe.spi.DefaultScheduledFuture
- get(long, TimeUnit) - Method in class dev.failsafe.spi.DefaultScheduledFuture
- get(AsyncExecution<R>) - Method in interface dev.failsafe.function.AsyncSupplier
- get(ExecutionContext<R>) - Method in interface dev.failsafe.function.ContextualSupplier
- get(CheckedSupplier<T>) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
supplier
until a successful result is returned or the configured policies are exceeded. - get(ContextualSupplier<R, R>, Executor) - Static method in class dev.failsafe.Functions
-
Returns a Supplier for synchronous executions that pre-executes the
execution
, applies thesupplier
, records the result and returns the result. - get(ContextualSupplier<T, T>) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
supplier
until a successful result is returned or the configured policies are exceeded. - getAbortConditions() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the conditions for which an execution result or exception will cause retries to be aborted.
- getAbortListener() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the abort event listener.
- getAsync(CheckedSupplier<T>) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
supplier
asynchronously until a successful result is returned or the configured policies are exceeded. - getAsync(ContextualSupplier<T, T>) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
supplier
asynchronously until a successful result is returned or the configured policies are exceeded. - getAsyncExecution(AsyncRunnable<T>) - Method in class dev.failsafe.FailsafeExecutor
-
This method is intended for integration with asynchronous code.
- getAttemptCount() - Method in class dev.failsafe.event.ExecutionEvent
-
Gets the number of execution attempts so far, including attempts that are blocked before being executed, such as when a
CircuitBreaker
is open. - getAttemptCount() - Method in interface dev.failsafe.ExecutionContext
-
Gets the number of execution attempts so far, including attempts that are blocked before being executed, such as when a
CircuitBreaker
is open. - getAttemptCount() - Method in class dev.failsafe.ExecutionImpl
- getAvailablePermits() - Method in class dev.failsafe.internal.BurstyRateLimiterStats
- getBulkhead() - Method in exception dev.failsafe.BulkheadFullException
-
Returns the
Bulkhead
that caused the exception. - getCircuitBreaker() - Method in exception dev.failsafe.CircuitBreakerOpenException
-
Returns the
CircuitBreaker
that caused the exception. - getCloseListener() - Method in class dev.failsafe.CircuitBreakerConfig
-
Returns the close event listener.
- getConfig() - Method in interface dev.failsafe.Bulkhead
-
Returns the
BulkheadConfig
that the Bulkhead was built with. - getConfig() - Method in interface dev.failsafe.CircuitBreaker
-
Returns the
CircuitBreakerConfig
that the CircuitBreaker was built with. - getConfig() - Method in interface dev.failsafe.Fallback
-
Returns the
FallbackConfig
that the Fallback was built with. - getConfig() - Method in class dev.failsafe.internal.BulkheadImpl
- getConfig() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- getConfig() - Method in class dev.failsafe.internal.FallbackImpl
- getConfig() - Method in class dev.failsafe.internal.RateLimiterImpl
- getConfig() - Method in class dev.failsafe.internal.RetryPolicyImpl
- getConfig() - Method in class dev.failsafe.internal.TimeoutImpl
- getConfig() - Method in interface dev.failsafe.Policy
-
Returns the policy config.
- getConfig() - Method in interface dev.failsafe.RateLimiter
-
Returns the
RateLimiterConfig
that the RateLimiter was built with. - getConfig() - Method in interface dev.failsafe.RetryPolicy
-
Returns the
RetryPolicyConfig
that the RetryPolicy was built with. - getConfig() - Method in interface dev.failsafe.spi.DelayablePolicy
- getConfig() - Method in interface dev.failsafe.spi.FailurePolicy
- getConfig() - Method in interface dev.failsafe.Timeout
-
Returns the
TimeoutConfig
that the Timeout was built with. - getCurrentBucket() - Method in class dev.failsafe.internal.TimedCircuitStats
-
Returns the current bucket based on the current time, moving the internal storage to the current bucket if necessary, resetting bucket stats along the way.
- getCurrentPeriod() - Method in class dev.failsafe.internal.BurstyRateLimiterStats
- getDelay() - Method in class dev.failsafe.CircuitBreakerConfig
-
Returns the delay before allowing another execution on the circuit.
- getDelay() - Method in class dev.failsafe.DelayablePolicyConfig
-
Returns the delay until the next execution attempt can be performed.
- getDelay() - Method in class dev.failsafe.event.ExecutionScheduledEvent
-
Returns the delay before the next execution attempt.
- getDelay() - Method in interface dev.failsafe.Execution
-
Returns the time to delay before the next execution attempt.
- getDelay() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the delay between retries, else
Duration.ZERO
if delays have not been configured. - getDelay() - Method in class dev.failsafe.spi.ExecutionResult
- getDelay() - Method in class dev.failsafe.SyncExecutionImpl
- getDelay(TimeUnit) - Method in class dev.failsafe.internal.util.DelegatingScheduler.ScheduledCompletableFuture
- getDelay(TimeUnit) - Method in class dev.failsafe.spi.DefaultScheduledFuture
- getDelayException() - Method in class dev.failsafe.DelayablePolicyConfig
-
Returns the Throwable that must be matched in order to delay using the
DelayablePolicyConfig.getDelayFn()
. - getDelayFactor() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the delay factor for backoff retries.
- getDelayFn() - Method in class dev.failsafe.DelayablePolicyConfig
-
Returns the function that determines the next delay before another execution can be performed.
- getDelayMax() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the max random delay between retries, else
null
if random delays have not been configured. - getDelayMin() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the min random delay between retries, else
null
if random delays have not been configured. - getDelayResult() - Method in class dev.failsafe.DelayablePolicyConfig
-
Returns the result that must be matched in order to delay using the
DelayablePolicyConfig.getDelayFn()
. - getElapsed() - Method in class dev.failsafe.internal.RateLimiterStats
-
Returns the elapsed time since the rate limiter began.
- getElapsedAttemptTime() - Method in class dev.failsafe.event.ExecutionEvent
-
Returns the elapsed time since the last execution attempt began.
- getElapsedAttemptTime() - Method in interface dev.failsafe.ExecutionContext
-
Returns the elapsed time since the last execution attempt began.
- getElapsedAttemptTime() - Method in class dev.failsafe.ExecutionImpl
- getElapsedTime() - Method in class dev.failsafe.event.ExecutionEvent
-
Returns the elapsed time since initial execution began.
- getElapsedTime() - Method in interface dev.failsafe.ExecutionContext
-
Returns the elapsed time since initial execution began.
- getElapsedTime() - Method in class dev.failsafe.ExecutionImpl
- getException() - Method in class dev.failsafe.event.ExecutionCompletedEvent
-
Returns the failure that preceded the event, else
null
if there was none. - getException() - Method in class dev.failsafe.spi.ExecutionResult
- getExecutionCount() - Method in interface dev.failsafe.CircuitBreaker
-
Returns the number of executions recorded in the current state when the state is CLOSED or HALF_OPEN.
- getExecutionCount() - Method in class dev.failsafe.event.ExecutionEvent
-
Gets the number of completed executions so far.
- getExecutionCount() - Method in interface dev.failsafe.ExecutionContext
-
Gets the number of completed executions so far.
- getExecutionCount() - Method in class dev.failsafe.ExecutionImpl
- getExecutionCount() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- getExecutionCount() - Method in interface dev.failsafe.internal.CircuitStats
- getExecutionCount() - Method in class dev.failsafe.internal.CountingCircuitStats
- getExecutionCount() - Method in class dev.failsafe.internal.DefaultCircuitStats
- getExecutionCount() - Method in class dev.failsafe.internal.TimedCircuitStats
- getFailedAttemptListener() - Method in class dev.failsafe.FallbackConfig
-
Returns the failed attempt event listener.
- getFailedAttemptListener() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the failed attempt event listener.
- getFailureConditions() - Method in class dev.failsafe.FailurePolicyConfig
-
Returns the conditions under which a result or Throwable should be treated as a failure and handled.
- getFailureCount() - Method in interface dev.failsafe.CircuitBreaker
-
Returns the number of failures recorded in the current state when the state is CLOSED or HALF_OPEN.
- getFailureCount() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- getFailureCount() - Method in interface dev.failsafe.internal.CircuitStats
- getFailureCount() - Method in class dev.failsafe.internal.CountingCircuitStats
- getFailureCount() - Method in class dev.failsafe.internal.DefaultCircuitStats
- getFailureCount() - Method in class dev.failsafe.internal.TimedCircuitStats
- getFailureExecutionThreshold() - Method in class dev.failsafe.CircuitBreakerConfig
-
Used with time based thresholding.
- getFailureListener() - Method in class dev.failsafe.PolicyConfig
-
Returns the failure listener.
- getFailureRate() - Method in interface dev.failsafe.CircuitBreaker
-
The percentage rate of failed executions, from 0 to 100, in the current state when the state is CLOSED or HALF_OPEN.
- getFailureRate() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- getFailureRate() - Method in interface dev.failsafe.internal.CircuitStats
- getFailureRate() - Method in class dev.failsafe.internal.CountingCircuitStats
- getFailureRate() - Method in class dev.failsafe.internal.DefaultCircuitStats
- getFailureRate() - Method in class dev.failsafe.internal.TimedCircuitStats
- getFailureRateThreshold() - Method in class dev.failsafe.CircuitBreakerConfig
-
Used with time based thresholding.
- getFailureThreshold() - Method in class dev.failsafe.CircuitBreakerConfig
-
Gets the number of failures that must occur within the
failure thresholding capacity
when in a CLOSED or HALF_OPEN state in order to open the circuit. - getFailureThresholdingCapacity() - Method in class dev.failsafe.CircuitBreakerConfig
-
Returns the rolling capacity for storing execution results when performing failure thresholding in the CLOSED or HALF_OPEN states.
- getFailureThresholdingPeriod() - Method in class dev.failsafe.CircuitBreakerConfig
-
Used with time based thresholding.
- getFallback() - Method in class dev.failsafe.FallbackConfig
-
Returns the fallback function, else
null
if a fallback stage function was configured instead. - getFallbackStage() - Method in class dev.failsafe.FallbackConfig
-
Returns the fallback stage function, else
null
if a fallback function was configured instead. - getFixedOrRandomDelayNanos(long) - Method in class dev.failsafe.internal.RetryPolicyExecutor
- getHalfOpenListener() - Method in class dev.failsafe.CircuitBreakerConfig
-
Returns the half-open event listener.
- getJitter() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the jitter, else
null
if none has been configured. - getJitterFactor() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the jitter factor, else
0.0
if none has been configured. - getLastException() - Method in class dev.failsafe.event.ExecutionAttemptedEvent
-
Returns the failure that preceded the event, else
null
if there was none. - getLastException() - Method in class dev.failsafe.event.ExecutionScheduledEvent
-
Returns the failure that preceded the event, else
null
if there was none. - getLastException() - Method in interface dev.failsafe.ExecutionContext
-
Returns the last exception that was recorded else
null
. - getLastException() - Method in class dev.failsafe.ExecutionImpl
- getLastResult() - Method in class dev.failsafe.event.ExecutionAttemptedEvent
-
Returns the result that preceded the event, else
null
if there was none. - getLastResult() - Method in class dev.failsafe.event.ExecutionScheduledEvent
-
Returns the result that preceded the event, else
null
if there was none. - getLastResult() - Method in interface dev.failsafe.ExecutionContext
-
Returns the last result that was recorded else
null
. - getLastResult() - Method in class dev.failsafe.ExecutionImpl
- getLastResult(R) - Method in interface dev.failsafe.ExecutionContext
-
Returns the last result that was recorded else the
defaultValue
. - getLastResult(R) - Method in class dev.failsafe.ExecutionImpl
- getLatest() - Method in class dev.failsafe.ExecutionImpl
- getLatest() - Method in interface dev.failsafe.spi.ExecutionInternal
-
Returns the most recent execution to be attempted.
- getLock() - Method in class dev.failsafe.ExecutionImpl
- getLock() - Method in interface dev.failsafe.spi.ExecutionInternal
-
Returns a lock object that is common across all execution attempts.
- getMaxAttempts() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the max number of execution attempts to perform.
- getMaxConcurrency() - Method in class dev.failsafe.BulkheadConfig
-
Returns that max concurrent executions that are permitted within the bulkhead.
- getMaxDelay() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the max delay between backoff retries, else
null
if backoff delays have not been configured. - getMaxDuration() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the max duration to perform retries for.
- getMaxPermits() - Method in class dev.failsafe.RateLimiterConfig
-
For bursty rate limiters, returns the max permitted executions per
period
, elsenull
if the rate limiter is not bursty. - getMaxRate() - Method in class dev.failsafe.RateLimiterConfig
-
For smooth rate limiters, returns the max rate at which individual executions are permitted, else
null
if the rate limiter is not smooth. - getMaxRetries() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the max number of retries to perform when an execution attempt fails.
- getMaxWaitTime() - Method in class dev.failsafe.BulkheadConfig
-
Returns the max time to wait for permits to be available.
- getMaxWaitTime() - Method in class dev.failsafe.RateLimiterConfig
-
Returns the max time to wait for permits to be available.
- getNextFreePermitNanos() - Method in class dev.failsafe.internal.SmoothRateLimiterStats
- getOpenListener() - Method in class dev.failsafe.CircuitBreakerConfig
-
Returns the open event listener.
- getPeriod() - Method in class dev.failsafe.RateLimiterConfig
-
For bursty rate limiters, returns the period after which permits are reset to
maxPermits
, elsenull
if the rate limiter is not bursty. - getPolicies() - Method in class dev.failsafe.FailsafeExecutor
-
Returns the currently configured policies.
- getPolicyIndex() - Method in class dev.failsafe.spi.PolicyExecutor
-
Returns the index of the policy relative to other policies in a composition, where the innermost policy in a composition has an index of
0
. - getPreviousState() - Method in class dev.failsafe.event.CircuitBreakerStateChangedEvent
-
Returns the previous state of the circuit breaker.
- getPromise(ContextualSupplier<R, R>, Executor) - Static method in class dev.failsafe.Functions
-
Returns a Function for asynchronous executions that pre-executes the
execution
, applies thesupplier
, records the result and returns a promise containing the result. - getPromiseExecution(AsyncRunnable<R>, Executor) - Static method in class dev.failsafe.Functions
-
Returns a Function for asynchronous executions that pre-executes the
execution
, runs therunnable
, and attempts to complete theexecution
if a failure occurs. - getPromiseOfStage(ContextualSupplier<R, ? extends CompletionStage<? extends R>>, FailsafeFuture<R>, Executor) - Static method in class dev.failsafe.Functions
-
Returns a Function that for asynchronous executions that pre-executes the
execution
, applies thesupplier
, records the result and returns a promise containing the result. - getRateLimiter() - Method in exception dev.failsafe.RateLimitExceededException
-
Returns the
RateLimiter
that caused the exception. - getRemainingDelay() - Method in interface dev.failsafe.CircuitBreaker
-
When in the OPEN state, returns the remaining delay until the circuit is half-opened and allows another execution, else returns
Duration.ZERO
. - getRemainingDelay() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- getRemainingDelay() - Method in class dev.failsafe.internal.CircuitState
- getRemainingDelay() - Method in class dev.failsafe.internal.OpenState
- getResult() - Method in class dev.failsafe.event.ExecutionCompletedEvent
-
Returns the result that preceded the event, else
null
if there was none. - getResult() - Method in class dev.failsafe.ExecutionImpl
- getResult() - Method in interface dev.failsafe.spi.ExecutionInternal
-
Returns the recorded result for an execution attempt.
- getResult() - Method in class dev.failsafe.spi.ExecutionResult
- getRetriesExceededListener() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the retries exceeded event listener.
- getRetryListener() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the retry event listener.
- getRetryScheduledListener() - Method in class dev.failsafe.RetryPolicyConfig
-
Returns the retry scheduled event listener.
- getStageAsync(CheckedSupplier<? extends CompletionStage<T>>) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
supplier
asynchronously until the resulting future is successfully completed or the configured policies are exceeded. - getStageAsync(ContextualSupplier<T, ? extends CompletionStage<T>>) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
supplier
asynchronously until the resulting future is successfully completed or the configured policies are exceeded. - getStartTime() - Method in class dev.failsafe.event.ExecutionEvent
-
Returns the time that the initial execution started, else
Optional.empty()
if an execution has not started yet. - getStartTime() - Method in interface dev.failsafe.ExecutionContext
-
Returns the time that the initial execution started.
- getStartTime() - Method in class dev.failsafe.ExecutionImpl
- getState() - Method in interface dev.failsafe.CircuitBreaker
-
Gets the state of the circuit.
- getState() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- getState() - Method in class dev.failsafe.internal.CircuitState
- getState() - Method in class dev.failsafe.internal.ClosedState
- getState() - Method in class dev.failsafe.internal.HalfOpenState
- getState() - Method in class dev.failsafe.internal.OpenState
- getStats() - Method in class dev.failsafe.internal.CircuitState
- getSuccessAll() - Method in class dev.failsafe.spi.ExecutionResult
-
Returns whether the execution was successful for all policies.
- getSuccessCount() - Method in interface dev.failsafe.CircuitBreaker
-
Returns the number of successes recorded in the current state when the state is CLOSED or HALF_OPEN.
- getSuccessCount() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- getSuccessCount() - Method in interface dev.failsafe.internal.CircuitStats
- getSuccessCount() - Method in class dev.failsafe.internal.CountingCircuitStats
- getSuccessCount() - Method in class dev.failsafe.internal.DefaultCircuitStats
- getSuccessCount() - Method in class dev.failsafe.internal.TimedCircuitStats
- getSuccessListener() - Method in class dev.failsafe.PolicyConfig
-
Returns the success listener.
- getSuccessRate() - Method in interface dev.failsafe.CircuitBreaker
-
The percentage rate of successful executions, from 0 to 100, in the current state when the state is CLOSED or HALF_OPEN.
- getSuccessRate() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- getSuccessRate() - Method in interface dev.failsafe.internal.CircuitStats
- getSuccessRate() - Method in class dev.failsafe.internal.CountingCircuitStats
- getSuccessRate() - Method in class dev.failsafe.internal.DefaultCircuitStats
- getSuccessRate() - Method in class dev.failsafe.internal.TimedCircuitStats
- getSuccessThreshold() - Method in class dev.failsafe.CircuitBreakerConfig
-
Gets the number of successes that must occur within the
success thresholding capacity
when in a HALF_OPEN state in order to open the circuit. - getSuccessThresholdingCapacity() - Method in class dev.failsafe.CircuitBreakerConfig
-
Returns the rolling capacity for storing execution results when performing success thresholding in the HALF_OPEN state.
- getTimeout() - Method in class dev.failsafe.TimeoutConfig
-
Returns the timeout duration.
- getTimeout() - Method in exception dev.failsafe.TimeoutExceededException
-
Returns the
Timeout
that caused the exception.
H
- HALF_OPEN - dev.failsafe.CircuitBreaker.State
-
The circuit is temporarily allowing executions to occur.
- halfOpen() - Method in interface dev.failsafe.CircuitBreaker
-
Half-opens the circuit.
- halfOpen() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- halfOpenListener - Variable in class dev.failsafe.CircuitBreakerConfig
- HalfOpenState<R> - Class in dev.failsafe.internal
- HalfOpenState(CircuitBreakerImpl<R>) - Constructor for class dev.failsafe.internal.HalfOpenState
- handle(ExecutionResult<R>, ExecutionContext<R>) - Method in interface dev.failsafe.internal.EventHandler
- handle(Class<? extends Throwable>) - Method in class dev.failsafe.FailurePolicyBuilder
-
Specifies the exception to handle as a failure.
- handle(Class<? extends Throwable>...) - Method in class dev.failsafe.FailurePolicyBuilder
-
Specifies the exceptions to handle as failures.
- handle(List<Class<? extends Throwable>>) - Method in class dev.failsafe.FailurePolicyBuilder
-
Specifies the exceptions to handle as failures.
- handleAsync(AsyncExecutionInternal<R>, Function<AsyncExecutionInternal<R>, CompletableFuture<ExecutionResult<R>>>, Scheduler, FailsafeFuture<R>, CompletableFuture<ExecutionResult<R>>, AtomicReference<ExecutionResult<R>>) - Method in class dev.failsafe.internal.RetryPolicyExecutor
- handleConfigChange() - Method in class dev.failsafe.internal.CircuitState
- handleConfigChange() - Method in class dev.failsafe.internal.ClosedState
- handleConfigChange() - Method in class dev.failsafe.internal.HalfOpenState
- handleExecutorThrowable(Throwable) - Static method in class dev.failsafe.Functions
- handleFailure(ExecutionResult<R>, ExecutionContext<R>) - Method in class dev.failsafe.spi.PolicyExecutor
- handleIf(CheckedBiPredicate<R, ? extends Throwable>) - Method in class dev.failsafe.FailurePolicyBuilder
-
Specifies that a failure has occurred if the
resultPredicate
matches the execution result. - handleIf(CheckedPredicate<? extends Throwable>) - Method in class dev.failsafe.FailurePolicyBuilder
-
Specifies that a failure has occurred if the
failurePredicate
matches the exception. - handleResult(R) - Method in class dev.failsafe.FailurePolicyBuilder
-
Specifies that a failure has occurred if the
result
matches the execution result. - handleResultIf(CheckedPredicate<R>) - Method in class dev.failsafe.FailurePolicyBuilder
-
Specifies that a failure has occurred if the
resultPredicate
matches the execution result. - handleSuccess(ExecutionResult<R>, ExecutionContext<R>) - Method in class dev.failsafe.spi.PolicyExecutor
- hashCode() - Method in class dev.failsafe.spi.ExecutionResult
- head - Variable in class dev.failsafe.internal.util.FutureLinkedList
I
- indexAfter(int) - Method in class dev.failsafe.internal.CountingCircuitStats
-
Returns the index after the
index
. - indexAfter(int) - Method in class dev.failsafe.internal.TimedCircuitStats
-
Returns the index after the
index
. - indexBefore(int) - Method in class dev.failsafe.internal.TimedCircuitStats
-
Returns the index before the
index
. - INSTANCE - Static variable in class dev.failsafe.internal.util.DelegatingScheduler
- interrupt() - Method in interface dev.failsafe.spi.SyncExecutionInternal
-
Interrupts the execution.
- interrupt() - Method in class dev.failsafe.SyncExecutionImpl
- interruptable - Variable in class dev.failsafe.SyncExecutionImpl
- interrupted - Variable in class dev.failsafe.SyncExecutionImpl
- intervalNanos - Variable in class dev.failsafe.internal.SmoothRateLimiterStats
- isAbortable(R, Throwable) - Method in class dev.failsafe.internal.RetryPolicyImpl
-
Returns whether an execution result can be aborted given the configured abort conditions.
- isAsync() - Method in class dev.failsafe.FallbackConfig
-
Returns whether the Fallback is configured to handle execution results asynchronously, separate from execution.
- isAsyncExecution() - Method in class dev.failsafe.AsyncExecutionImpl
- isAsyncExecution() - Method in interface dev.failsafe.spi.AsyncExecutionInternal
-
Returns whether the execution is an async integration execution.
- isBursty() - Method in interface dev.failsafe.RateLimiter
-
Returns whether the rate limiter is bursty.
- isCancelled() - Method in interface dev.failsafe.Call
-
Returns whether the call has been cancelled.
- isCancelled() - Method in class dev.failsafe.CallImpl
- isCancelled() - Method in interface dev.failsafe.ExecutionContext
-
Returns whether the execution has been cancelled.
- isCancelled() - Method in class dev.failsafe.ExecutionImpl
- isCancelled() - Method in class dev.failsafe.spi.DefaultScheduledFuture
- isCancelled(PolicyExecutor<R>) - Method in class dev.failsafe.ExecutionImpl
- isCancelled(PolicyExecutor<R>) - Method in interface dev.failsafe.spi.ExecutionInternal
-
Returns whether the execution is considered cancelled for the
policyExecutor
. - isClosed() - Method in interface dev.failsafe.CircuitBreaker
-
Returns whether the circuit is closed.
- isClosed() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- isComplete() - Method in interface dev.failsafe.AsyncExecution
-
Returns whether the execution is complete or if it can be retried.
- isComplete() - Method in class dev.failsafe.AsyncExecutionImpl
- isComplete() - Method in interface dev.failsafe.Execution
-
Returns whether the execution is complete or if it can be retried.
- isComplete() - Method in class dev.failsafe.spi.ExecutionResult
- isComplete() - Method in class dev.failsafe.SyncExecutionImpl
- isDone() - Method in class dev.failsafe.spi.DefaultScheduledFuture
- isExceptionsChecked() - Method in class dev.failsafe.FailurePolicyConfig
-
Returns whether exceptions are checked by a configured failure condition.
- isFailure(ExecutionResult<R>) - Method in class dev.failsafe.internal.TimeoutExecutor
- isFailure(ExecutionResult<R>) - Method in class dev.failsafe.spi.PolicyExecutor
-
Returns whether the
result
is a success according to the policy. - isFailure(R, Throwable) - Method in interface dev.failsafe.spi.FailurePolicy
-
Returns whether an execution
result
orexception
are considered a failure according to the policy configuration. - isFirstAttempt() - Method in class dev.failsafe.event.ExecutionEvent
-
Returns
true
whenExecutionEvent.getAttemptCount()
is0
meaning this is the first execution attempt. - isFirstAttempt() - Method in interface dev.failsafe.ExecutionContext
-
Returns
true
when an execution result has not yet been recorded, meaning this is the first execution attempt. - isFirstAttempt() - Method in class dev.failsafe.ExecutionImpl
- isHalfOpen() - Method in interface dev.failsafe.CircuitBreaker
-
Returns whether the circuit is half open.
- isHalfOpen() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- isInterrupted() - Method in interface dev.failsafe.spi.SyncExecutionInternal
-
Returns whether the execution is currently interrupted.
- isInterrupted() - Method in class dev.failsafe.SyncExecutionImpl
- isNonResult() - Method in class dev.failsafe.spi.ExecutionResult
- isOpen() - Method in interface dev.failsafe.CircuitBreaker
-
Returns whether the circuit is open.
- isOpen() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- isPostExecuted(int) - Method in class dev.failsafe.AsyncExecutionImpl
- isPostExecuted(int) - Method in interface dev.failsafe.spi.AsyncExecutionInternal
-
Returns whether the PolicyExecutor corresponding to the
policyIndex
has already post-executed. - isPreExecuted() - Method in class dev.failsafe.ExecutionImpl
- isPreExecuted() - Method in interface dev.failsafe.spi.ExecutionInternal
-
Returns whether the execution has been pre-executed, indicating the attempt has started.
- isRecorded() - Method in class dev.failsafe.AsyncExecutionImpl
- isRecorded() - Method in interface dev.failsafe.spi.AsyncExecutionInternal
-
Returns whether one of the public
AsyncExecution
record or complete methods have been called. - isRetry() - Method in class dev.failsafe.event.ExecutionEvent
- isRetry() - Method in interface dev.failsafe.ExecutionContext
-
Returns
true
when an execution result has already been recorded, meaning the execution is being retried. - isRetry() - Method in class dev.failsafe.ExecutionImpl
- isSmooth() - Method in interface dev.failsafe.RateLimiter
-
Returns whether the rate limiter is smooth.
- isStandalone() - Method in class dev.failsafe.SyncExecutionImpl
- isSuccess() - Method in class dev.failsafe.spi.ExecutionResult
- isTrue(boolean, String, Object...) - Static method in class dev.failsafe.internal.util.Assert
- isValidResult(ExecutionResult<R>, Throwable, CompletableFuture<ExecutionResult<R>>) - Method in class dev.failsafe.internal.RetryPolicyExecutor
-
Completes the
promise
and returnsfalse
if theresult
orerror
are invalid, else returnstrue
.
J
- jitter - Variable in class dev.failsafe.RetryPolicyConfig
- jitterFactor - Variable in class dev.failsafe.RetryPolicyConfig
L
- lastDelayNanos - Variable in class dev.failsafe.internal.RetryPolicyExecutor
-
The last fixed, backoff, random or computed delay time in nanoseconds.
- latest - Variable in class dev.failsafe.ExecutionImpl
- Lists - Class in dev.failsafe.internal.util
-
List utilities.
- Lists() - Constructor for class dev.failsafe.internal.util.Lists
M
- Maths - Class in dev.failsafe.internal.util
-
Misc math utilities.
- Maths() - Constructor for class dev.failsafe.internal.util.Maths
- MAX_SAFE_NANOS_DURATION - Static variable in class dev.failsafe.internal.util.Durations
- MAX_SECONDS_PER_LONG - Static variable in class dev.failsafe.internal.util.Durations
- maxConcurrency - Variable in class dev.failsafe.BulkheadConfig
- maxDelay - Variable in class dev.failsafe.RetryPolicyConfig
- maxDuration - Variable in class dev.failsafe.RetryPolicyConfig
- maxPermits - Variable in class dev.failsafe.internal.BulkheadImpl
- maxPermits - Variable in class dev.failsafe.RateLimiterConfig
- maxRate - Variable in class dev.failsafe.RateLimiterConfig
- maxRetries - Variable in class dev.failsafe.RetryPolicyConfig
- maxWaitTime - Variable in class dev.failsafe.BulkheadConfig
- maxWaitTime - Variable in class dev.failsafe.internal.BulkheadExecutor
- maxWaitTime - Variable in class dev.failsafe.internal.RateLimiterExecutor
- maxWaitTime - Variable in class dev.failsafe.RateLimiterConfig
N
- newCall(ContextualRunnable<Void>) - Method in class dev.failsafe.FailsafeExecutor
-
Returns a call that can execute the
runnable
until a successful result is returned or the configured policies are exceeded. - newCall(ContextualSupplier<T, T>) - Method in class dev.failsafe.FailsafeExecutor
-
Returns a call that can execute the
supplier
until a successful result is returned or the configured policies are exceeded. - newestExecution - Variable in class dev.failsafe.spi.FailsafeFuture
- newThread(Runnable) - Method in class dev.failsafe.internal.util.DelegatingScheduler.DelayerThreadFactory
- next - Variable in class dev.failsafe.internal.util.FutureLinkedList.Node
- nextFreePermitNanos - Variable in class dev.failsafe.internal.SmoothRateLimiterStats
- nextIndex() - Method in class dev.failsafe.internal.TimedCircuitStats
-
Returns the next index.
- Node() - Constructor for class dev.failsafe.internal.util.FutureLinkedList.Node
- none() - Static method in class dev.failsafe.Failsafe
-
Creates and returns a noop
FailsafeExecutor
instance that treats any exception as a failure for the purposes of calling event listeners, and provides no additional failure handling. - none() - Static method in interface dev.failsafe.Fallback
-
Returns a fallback that will return a null if execution fails.
- none() - Static method in class dev.failsafe.spi.ExecutionResult
-
Returns an execution that was completed with a non-result.
- NONE - Static variable in class dev.failsafe.internal.FallbackImpl
-
A fallback that will return null if execution fails.
- NONE - Static variable in class dev.failsafe.spi.ExecutionResult
- nonResult - Variable in class dev.failsafe.spi.ExecutionResult
-
Whether the result represents a non result rather than a
null
result - notNull(T, String) - Static method in class dev.failsafe.internal.util.Assert
- NULL_FUTURE - Static variable in class dev.failsafe.internal.BulkheadImpl
- NULL_FUTURE - Static variable in class dev.failsafe.spi.ExecutionResult
- nullFuture() - Static method in class dev.failsafe.spi.ExecutionResult
-
Returns a CompletableFuture that is completed with
null
.
O
- occupiedBits - Variable in class dev.failsafe.internal.CountingCircuitStats
- of(int) - Static method in interface dev.failsafe.Bulkhead
-
Returns a Bulkhead for the
maxConcurrency
that haszero wait
. - of(CheckedConsumer<ExecutionAttemptedEvent<? extends R>>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - of(CheckedFunction<ExecutionAttemptedEvent<? extends R>, ? extends R>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - of(CheckedRunnable) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - of(CheckedSupplier<? extends R>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - of(Policy<R>, Policy<R>...) - Static method in interface dev.failsafe.Execution
-
Creates a new
Execution
that will use theouterPolicy
andinnerPolicies
to handle failures. - of(Duration) - Static method in interface dev.failsafe.Timeout
- of(ExecutorService) - Static method in interface dev.failsafe.spi.Scheduler
-
Returns a Scheduler adapted from the
executorService
. - of(ScheduledExecutorService) - Static method in interface dev.failsafe.spi.Scheduler
-
Returns a Scheduler adapted from the
scheduledExecutorService
. - of(R) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallbackResult
to be provided if execution fails. - of(T, T[]) - Static method in class dev.failsafe.internal.util.Lists
-
Returns a list containing the
first
element followed by therest
. - ofDefaults() - Static method in interface dev.failsafe.CircuitBreaker
- ofDefaults() - Static method in interface dev.failsafe.RetryPolicy
-
Creates a RetryPolicy that allows 3 execution attempts max with no delay.
- ofException(CheckedFunction<ExecutionAttemptedEvent<? extends R>, ? extends Exception>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails and allows an alternative exception to be supplied instead. - ofExecutionAttempted(EventListener<ExecutionAttemptedEvent<R>>) - Static method in interface dev.failsafe.internal.EventHandler
- ofExecutionCompleted(EventListener<ExecutionCompletedEvent<R>>) - Static method in interface dev.failsafe.internal.EventHandler
- ofExecutionScheduled(EventListener<ExecutionScheduledEvent<R>>) - Static method in interface dev.failsafe.internal.EventHandler
- ofSafeNanos(Duration) - Static method in class dev.failsafe.internal.util.Durations
-
Returns either the
duration
else a Duration containing the max seconds that can safely be converted to nanos without overflowing. - ofStage(CheckedFunction<ExecutionAttemptedEvent<? extends R>, ? extends CompletionStage<R>>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - ofStage(CheckedSupplier<? extends CompletionStage<R>>) - Static method in interface dev.failsafe.Fallback
-
Returns the
fallback
to be executed if execution fails. - onAbort(EventListener<ExecutionCompletedEvent<R>>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Registers the
listener
to be called when an execution is aborted. - onCancel(CheckedRunnable) - Method in interface dev.failsafe.ExecutionContext
- onCancel(CheckedRunnable) - Method in class dev.failsafe.ExecutionImpl
- onClose(EventListener<CircuitBreakerStateChangedEvent>) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Calls the
listener
when the circuit is closed. - onComplete(EventListener<ExecutionCompletedEvent<R>>) - Method in class dev.failsafe.FailsafeExecutor
-
Registers the
listener
to be called when an execution is complete. - onFailedAttempt(EventListener<ExecutionAttemptedEvent<R>>) - Method in class dev.failsafe.FallbackBuilder
-
Registers the
listener
to be called when the last execution attempt prior to the fallback failed. - onFailedAttempt(EventListener<ExecutionAttemptedEvent<R>>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Registers the
listener
to be called when an execution attempt fails. - onFailure(EventListener<ExecutionCompletedEvent<R>>) - Method in class dev.failsafe.FailsafeExecutor
-
Registers the
listener
to be called when an execution fails. - onFailure(EventListener<ExecutionCompletedEvent<R>>) - Method in class dev.failsafe.PolicyBuilder
- onFailure(EventListener<ExecutionCompletedEvent<R>>) - Method in interface dev.failsafe.PolicyListeners
-
Registers the
listener
to be called when the policy fails to handle an execution. - onFailure(ExecutionContext<R>, ExecutionResult<R>) - Method in class dev.failsafe.internal.BulkheadExecutor
- onFailure(ExecutionContext<R>, ExecutionResult<R>) - Method in class dev.failsafe.internal.CircuitBreakerExecutor
- onFailure(ExecutionContext<R>, ExecutionResult<R>) - Method in class dev.failsafe.internal.RetryPolicyExecutor
- onFailure(ExecutionContext<R>, ExecutionResult<R>) - Method in class dev.failsafe.spi.PolicyExecutor
-
Performs post-execution handling for a
result
that is considered a failure according toPolicyExecutor.isFailure(ExecutionResult)
, possibly creating a new result, else returning the originalresult
. - onFailureAsync(ExecutionContext<R>, ExecutionResult<R>, Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.internal.RetryPolicyExecutor
-
Defaults async executions to not be complete until
says they are
. - onFailureAsync(ExecutionContext<R>, ExecutionResult<R>, Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.spi.PolicyExecutor
-
Performs potentially asynchrononus post-execution handling for a failed
result
, possibly creating a new result, else returning the originalresult
. - onHalfOpen(EventListener<CircuitBreakerStateChangedEvent>) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Calls the
listener
when the circuit is half-opened. - onOpen(EventListener<CircuitBreakerStateChangedEvent>) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Calls the
listener
when the circuit is opened. - onRetriesExceeded(EventListener<ExecutionCompletedEvent<R>>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Registers the
listener
to be called when an execution fails and themax retry attempts
ormax duration
are exceeded. - onRetry(EventListener<ExecutionAttemptedEvent<R>>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Registers the
listener
to be called when a retry is about to be attempted. - onRetryScheduled(EventListener<ExecutionScheduledEvent<R>>) - Method in class dev.failsafe.RetryPolicyBuilder
-
Registers the
listener
to be called when a retry for an async call is about to be scheduled. - onSuccess(EventListener<ExecutionCompletedEvent<R>>) - Method in class dev.failsafe.FailsafeExecutor
-
Registers the
listener
to be called when an execution is successful. - onSuccess(EventListener<ExecutionCompletedEvent<R>>) - Method in class dev.failsafe.PolicyBuilder
- onSuccess(EventListener<ExecutionCompletedEvent<R>>) - Method in interface dev.failsafe.PolicyListeners
-
Registers the
listener
to be called when the policy succeeds in handling an execution. - onSuccess(ExecutionResult<R>) - Method in class dev.failsafe.internal.BulkheadExecutor
- onSuccess(ExecutionResult<R>) - Method in class dev.failsafe.internal.CircuitBreakerExecutor
- onSuccess(ExecutionResult<R>) - Method in class dev.failsafe.spi.PolicyExecutor
-
Performs post-execution handling for a
result
that is considered a success according toPolicyExecutor.isFailure(ExecutionResult)
. - open() - Method in interface dev.failsafe.CircuitBreaker
-
Opens the circuit.
- open() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- open(ExecutionContext<R>) - Method in class dev.failsafe.internal.CircuitBreakerImpl
-
Opens the circuit breaker and considers the
context
when computing the delay before the circuit breaker will transition to half open. - OPEN - dev.failsafe.CircuitBreaker.State
-
The circuit is opened and not allowing executions to occur.
- openListener - Variable in class dev.failsafe.CircuitBreakerConfig
- OpenState<R> - Class in dev.failsafe.internal
- OpenState(CircuitBreakerImpl<R>, CircuitState<R>, Duration) - Constructor for class dev.failsafe.internal.OpenState
- outerFn - Variable in class dev.failsafe.AsyncExecutionImpl
- outerFn - Variable in class dev.failsafe.SyncExecutionImpl
P
- period - Variable in class dev.failsafe.RateLimiterConfig
- periodNanos - Variable in class dev.failsafe.internal.BurstyRateLimiterStats
- periodPermits - Variable in class dev.failsafe.internal.BurstyRateLimiterStats
- permits - Variable in class dev.failsafe.internal.BulkheadImpl
- permittedExecutions - Variable in class dev.failsafe.internal.HalfOpenState
- policies - Variable in class dev.failsafe.FailsafeExecutor
-
Policies sorted outermost first
- policy - Variable in class dev.failsafe.internal.TimeoutExecutor
- Policy<R> - Interface in dev.failsafe
-
A policy for handling executions.
- PolicyBuilder<S,C extends PolicyConfig<R>,R> - Class in dev.failsafe
-
Builds policies.
- PolicyBuilder(C) - Constructor for class dev.failsafe.PolicyBuilder
- PolicyConfig<R> - Class in dev.failsafe
-
Configuration for a
Policy
. - PolicyConfig() - Constructor for class dev.failsafe.PolicyConfig
- PolicyConfig(PolicyConfig<R>) - Constructor for class dev.failsafe.PolicyConfig
- PolicyExecutor<R> - Class in dev.failsafe.spi
-
Handles execution and execution results according to a policy.
- PolicyExecutor(Policy<R>, int) - Constructor for class dev.failsafe.spi.PolicyExecutor
- policyExecutors - Variable in class dev.failsafe.ExecutionImpl
- policyIndex - Variable in class dev.failsafe.spi.PolicyExecutor
-
Index of the policy relative to other policies in a composition, innermost first
- PolicyListeners<S,R> - Interface in dev.failsafe
-
Configures listeners for a policy execution result.
- policyPostExecuted - Variable in class dev.failsafe.AsyncExecutionImpl
- pollFirst() - Method in class dev.failsafe.internal.util.FutureLinkedList
-
Returns and removes the first future in the list, else returns
null
if the list is empty. - postExecute(ExecutionInternal<R>, ExecutionResult<R>) - Method in class dev.failsafe.spi.PolicyExecutor
-
Performs synchronous post-execution handling for a
result
. - postExecute(ExecutionResult<R>) - Method in class dev.failsafe.ExecutionImpl
-
Externally called.
- postExecute(ExecutionResult<R>) - Method in class dev.failsafe.SyncExecutionImpl
- postExecuteAsync(AsyncExecutionInternal<R>, ExecutionResult<R>, Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.spi.PolicyExecutor
-
Performs potentially asynchronous post-execution handling for a
result
. - preExecute() - Method in class dev.failsafe.ExecutionImpl
- preExecute() - Method in class dev.failsafe.internal.BulkheadExecutor
- preExecute() - Method in class dev.failsafe.internal.CircuitBreakerExecutor
- preExecute() - Method in class dev.failsafe.internal.RateLimiterExecutor
- preExecute() - Method in interface dev.failsafe.spi.ExecutionInternal
-
Called when execution of the user's supplier is about to begin.
- preExecute() - Method in class dev.failsafe.spi.PolicyExecutor
-
Called before execution to return an alternative result or exception such as if execution is not allowed or needed.
- preExecute() - Method in class dev.failsafe.SyncExecutionImpl
- preExecuteAsync(Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.internal.BulkheadExecutor
- preExecuteAsync(Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.internal.RateLimiterExecutor
- preExecuteAsync(Scheduler, FailsafeFuture<R>) - Method in class dev.failsafe.spi.PolicyExecutor
-
Called before an async execution to return an alternative result or exception such as if execution is not allowed or needed.
- preExecuted - Variable in class dev.failsafe.ExecutionImpl
- previous - Variable in class dev.failsafe.internal.util.FutureLinkedList.Node
- previousResult - Variable in class dev.failsafe.ExecutionImpl
- previousState - Variable in class dev.failsafe.event.CircuitBreakerStateChangedEvent
- propagateCancellation(Future<R>) - Method in class dev.failsafe.spi.FailsafeFuture
-
Propogates any previous cancellation to the
future
, either by cancelling it immediately or setting a cancel function to cancel it later.
R
- randomDelay(long, double, double) - Static method in class dev.failsafe.internal.util.RandomDelay
- randomDelay(long, long, double) - Static method in class dev.failsafe.internal.util.RandomDelay
- RandomDelay - Class in dev.failsafe.internal.util
-
Utilities for computing random delays.
- RandomDelay() - Constructor for class dev.failsafe.internal.util.RandomDelay
- randomDelayInRange(long, long, double) - Static method in class dev.failsafe.internal.util.RandomDelay
- rateLimiter - Variable in class dev.failsafe.internal.RateLimiterExecutor
- rateLimiter - Variable in exception dev.failsafe.RateLimitExceededException
- RateLimiter<R> - Interface in dev.failsafe
-
A rate limiter allows you to control the rate of executions as a way of preventing system overload.
- RateLimiterBuilder<R> - Class in dev.failsafe
-
Builds
RateLimiter
instances. - RateLimiterBuilder(long, Duration) - Constructor for class dev.failsafe.RateLimiterBuilder
- RateLimiterBuilder(RateLimiterConfig<R>) - Constructor for class dev.failsafe.RateLimiterBuilder
- RateLimiterBuilder(Duration) - Constructor for class dev.failsafe.RateLimiterBuilder
- RateLimiterConfig<R> - Class in dev.failsafe
-
Configuration for a
RateLimiter
. - RateLimiterConfig(long, Duration) - Constructor for class dev.failsafe.RateLimiterConfig
- RateLimiterConfig(RateLimiterConfig<R>) - Constructor for class dev.failsafe.RateLimiterConfig
- RateLimiterConfig(Duration) - Constructor for class dev.failsafe.RateLimiterConfig
- RateLimiterExecutor<R> - Class in dev.failsafe.internal
-
A PolicyExecutor that handles failures according to a
RateLimiter
. - RateLimiterExecutor(RateLimiterImpl<R>, int) - Constructor for class dev.failsafe.internal.RateLimiterExecutor
- RateLimiterImpl<R> - Class in dev.failsafe.internal
-
A RateLimiter implementation that supports smooth and bursty rate limiting.
- RateLimiterImpl(RateLimiterConfig<R>) - Constructor for class dev.failsafe.internal.RateLimiterImpl
- RateLimiterImpl(RateLimiterConfig<R>, RateLimiterStats.Stopwatch) - Constructor for class dev.failsafe.internal.RateLimiterImpl
- RateLimiterStats - Class in dev.failsafe.internal
- RateLimiterStats(RateLimiterStats.Stopwatch) - Constructor for class dev.failsafe.internal.RateLimiterStats
- RateLimiterStats.Stopwatch - Class in dev.failsafe.internal
- RateLimitExceededException - Exception in dev.failsafe
-
Thrown when an execution exceeds or would exceed a
RateLimiter
. - RateLimitExceededException(RateLimiter<?>) - Constructor for exception dev.failsafe.RateLimitExceededException
- record(ExecutionResult<R>) - Method in class dev.failsafe.ExecutionImpl
- record(ExecutionResult<R>) - Method in interface dev.failsafe.spi.ExecutionInternal
-
Records the
result
if the execution has beenpre-executed
and a result has not already been recorded. - record(R, Throwable) - Method in interface dev.failsafe.AsyncExecution
-
Records an execution
result
orexception
which triggers failure handling, if needed, by the configured policies. - record(R, Throwable) - Method in class dev.failsafe.AsyncExecutionImpl
- record(R, Throwable) - Method in interface dev.failsafe.Execution
-
Records an execution
result
orexception
which triggers failure handling, if needed, by the configured policies. - record(R, Throwable) - Method in class dev.failsafe.SyncExecutionImpl
- recordAttempt() - Method in class dev.failsafe.ExecutionImpl
- recordAttempt() - Method in interface dev.failsafe.spi.ExecutionInternal
-
Records an execution attempt which may correspond with an execution result.
- recorded - Variable in class dev.failsafe.AsyncExecutionImpl
- recordException(Throwable) - Method in interface dev.failsafe.AsyncExecution
-
Records an
exception
which triggers failure handling, if needed, by the configured policies. - recordException(Throwable) - Method in class dev.failsafe.AsyncExecutionImpl
- recordException(Throwable) - Method in interface dev.failsafe.CircuitBreaker
-
Records an
exception
as a success or failure based on the failure configuration. - recordException(Throwable) - Method in interface dev.failsafe.Execution
-
Records an
exception
which triggers failure handling, if needed, by the configured policies. - recordException(Throwable) - Method in class dev.failsafe.internal.CircuitBreakerImpl
- recordException(Throwable) - Method in class dev.failsafe.SyncExecutionImpl
- recordExecutionFailure(ExecutionContext<R>) - Method in class dev.failsafe.internal.CircuitBreakerImpl
-
Records an execution failure.
- recordFailure() - Method in interface dev.failsafe.CircuitBreaker
-
Records an execution failure.
- recordFailure() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- recordFailure() - Method in interface dev.failsafe.internal.CircuitStats
- recordFailure() - Method in class dev.failsafe.internal.CountingCircuitStats
- recordFailure() - Method in class dev.failsafe.internal.DefaultCircuitStats
- recordFailure() - Method in class dev.failsafe.internal.TimedCircuitStats
- recordFailure(ExecutionContext<R>) - Method in class dev.failsafe.internal.CircuitState
- recordResult(R) - Method in interface dev.failsafe.AsyncExecution
-
Records an execution
result
which triggers failure handling, if needed, by the configured policies. - recordResult(R) - Method in class dev.failsafe.AsyncExecutionImpl
- recordResult(R) - Method in interface dev.failsafe.CircuitBreaker
-
Records an execution
result
as a success or failure based on the failure configuration. - recordResult(R) - Method in interface dev.failsafe.Execution
-
Records an execution
result
which triggers failure handling, if needed, by the configured policies. - recordResult(R) - Method in class dev.failsafe.internal.CircuitBreakerImpl
- recordResult(R) - Method in class dev.failsafe.SyncExecutionImpl
- recordResult(R, Throwable) - Method in class dev.failsafe.internal.CircuitBreakerImpl
- recordSuccess() - Method in interface dev.failsafe.CircuitBreaker
-
Records an execution success.
- recordSuccess() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- recordSuccess() - Method in class dev.failsafe.internal.CircuitState
- recordSuccess() - Method in interface dev.failsafe.internal.CircuitStats
- recordSuccess() - Method in class dev.failsafe.internal.CountingCircuitStats
- recordSuccess() - Method in class dev.failsafe.internal.DefaultCircuitStats
- recordSuccess() - Method in class dev.failsafe.internal.TimedCircuitStats
- releasePermit() - Method in interface dev.failsafe.Bulkhead
-
Releases a permit to execute.
- releasePermit() - Method in class dev.failsafe.internal.BulkheadImpl
- releasePermit() - Method in class dev.failsafe.internal.CircuitState
- releasePermit() - Method in class dev.failsafe.internal.HalfOpenState
- remove(TimedCircuitStats.Bucket) - Method in class dev.failsafe.internal.TimedCircuitStats.Stat
- remove(FutureLinkedList.Node) - Method in class dev.failsafe.internal.util.FutureLinkedList
- reservePermit() - Method in interface dev.failsafe.RateLimiter
-
Reserves a permit to perform an execution against the rate limiter, and returns the time that the caller is expected to wait before acting on the permit.
- reservePermits(int) - Method in class dev.failsafe.internal.RateLimiterImpl
- reservePermits(int) - Method in interface dev.failsafe.RateLimiter
-
Reserves the
permits
to perform executions against the rate limiter, and returns the time that the caller is expected to wait before acting on the permits. - reservePermits(int, Duration) - Method in class dev.failsafe.internal.RateLimiterImpl
- reset() - Method in class dev.failsafe.internal.BurstyRateLimiterStats
- reset() - Method in interface dev.failsafe.internal.CircuitStats
- reset() - Method in class dev.failsafe.internal.CountingCircuitStats
- reset() - Method in class dev.failsafe.internal.DefaultCircuitStats
- reset() - Method in class dev.failsafe.internal.RateLimiterStats
-
Resets the rate limiter's internal stats.
- reset() - Method in class dev.failsafe.internal.RateLimiterStats.Stopwatch
- reset() - Method in class dev.failsafe.internal.SmoothRateLimiterStats
- reset() - Method in class dev.failsafe.internal.TimedCircuitStats
- reset() - Method in class dev.failsafe.internal.TimedCircuitStats.Stat
- reset(long) - Method in class dev.failsafe.internal.TimedCircuitStats.Bucket
- result - Variable in class dev.failsafe.event.ExecutionAttemptedEvent
- result - Variable in class dev.failsafe.event.ExecutionCompletedEvent
- result - Variable in class dev.failsafe.event.ExecutionScheduledEvent
- result - Variable in class dev.failsafe.ExecutionImpl
- result - Variable in class dev.failsafe.internal.DefaultCircuitStats
- result - Variable in class dev.failsafe.spi.ExecutionResult
-
The execution result, if any
- resultPredicateFor(CheckedPredicate<R>) - Static method in class dev.failsafe.FailurePolicyBuilder
-
Returns a predicate that evaluates the
resultPredicate
against a result, when present. - resultPredicateFor(R) - Static method in class dev.failsafe.FailurePolicyBuilder
-
Returns a predicate that evaluates whether the
result
equals an execution result. - retriesExceeded - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- retriesExceededHandler - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- retriesExceededListener - Variable in class dev.failsafe.RetryPolicyConfig
- retryHandler - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- retryListener - Variable in class dev.failsafe.RetryPolicyConfig
- retryPolicy - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- RetryPolicy<R> - Interface in dev.failsafe
-
A policy that defines when retries should be performed.
- RetryPolicyBuilder<R> - Class in dev.failsafe
-
Builds
RetryPolicy
instances. - RetryPolicyBuilder() - Constructor for class dev.failsafe.RetryPolicyBuilder
- RetryPolicyBuilder(RetryPolicyConfig<R>) - Constructor for class dev.failsafe.RetryPolicyBuilder
- RetryPolicyConfig<R> - Class in dev.failsafe
-
Configuration for a
RetryPolicy
. - RetryPolicyConfig() - Constructor for class dev.failsafe.RetryPolicyConfig
- RetryPolicyConfig(RetryPolicyConfig<R>) - Constructor for class dev.failsafe.RetryPolicyConfig
- RetryPolicyExecutor<R> - Class in dev.failsafe.internal
-
A PolicyExecutor that handles failures according to a
RetryPolicy
. - RetryPolicyExecutor(RetryPolicyImpl<R>, int) - Constructor for class dev.failsafe.internal.RetryPolicyExecutor
- RetryPolicyImpl<R> - Class in dev.failsafe.internal
-
A
RetryPolicy
implementation. - RetryPolicyImpl(RetryPolicyConfig<R>) - Constructor for class dev.failsafe.internal.RetryPolicyImpl
- retryScheduledHandler - Variable in class dev.failsafe.internal.RetryPolicyExecutor
- retryScheduledListener - Variable in class dev.failsafe.RetryPolicyConfig
- roundDown(long, long) - Static method in class dev.failsafe.internal.util.Maths
-
Returns the
input
rounded down to the nearestinterval
. - run() - Method in interface dev.failsafe.function.CheckedRunnable
- run(AsyncExecution<R>) - Method in interface dev.failsafe.function.AsyncRunnable
- run(ExecutionContext<R>) - Method in interface dev.failsafe.function.ContextualRunnable
- run(CheckedRunnable) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
runnable
until successful or until the configured policies are exceeded. - run(ContextualRunnable<Void>) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
runnable
until successful or until the configured policies are exceeded. - runAsync(CheckedRunnable) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
runnable
asynchronously until successful or until the configured policies are exceeded. - runAsync(ContextualRunnable<Void>) - Method in class dev.failsafe.FailsafeExecutor
-
Executes the
runnable
asynchronously until successful or until the configured policies are exceeded. - runAsyncExecution(AsyncRunnable<Void>) - Method in class dev.failsafe.FailsafeExecutor
-
This method is intended for integration with asynchronous code.
S
- schedule(Callable<?>, long, TimeUnit) - Method in class dev.failsafe.internal.util.DelegatingScheduler
- schedule(Callable<?>, long, TimeUnit) - Method in interface dev.failsafe.spi.Scheduler
-
Schedules the
callable
to be called after thedelay
for theunit
. - ScheduledCompletableFuture(long, TimeUnit) - Constructor for class dev.failsafe.internal.util.DelegatingScheduler.ScheduledCompletableFuture
- scheduler - Variable in class dev.failsafe.FailsafeExecutor
- Scheduler - Interface in dev.failsafe.spi
-
Schedules executions.
- serialVersionUID - Static variable in exception dev.failsafe.BulkheadFullException
- serialVersionUID - Static variable in exception dev.failsafe.CircuitBreakerOpenException
- serialVersionUID - Static variable in exception dev.failsafe.FailsafeException
- serialVersionUID - Static variable in exception dev.failsafe.RateLimitExceededException
- serialVersionUID - Static variable in exception dev.failsafe.TimeoutExceededException
- setCancelFn(int, BiConsumer<Boolean, ExecutionResult<R>>) - Method in class dev.failsafe.spi.FailsafeFuture
-
Sets a
cancelFn
to be called when a PolicyExecutorcancels dependencies
with a policyIndex > the givenpolicyIndex
, or when this future iscancelled
. - setCancelFn(PolicyExecutor<R>, BiConsumer<Boolean, ExecutionResult<R>>) - Method in class dev.failsafe.spi.FailsafeFuture
-
Sets a
cancelFn
to be called when a PolicyExecutorcancels dependencies
with a policyIndex > the policyIndex of the givenpolicyExecutor
, or when this future iscancelled
. - setExecution(ExecutionInternal<R>) - Method in class dev.failsafe.spi.FailsafeFuture
-
Sets the
execution
representing the most recent attempt, which will be cancelled if this future is cancelled. - setExecution(SyncExecutionImpl<R>) - Method in class dev.failsafe.CallImpl
- setInterruptable(boolean) - Method in interface dev.failsafe.spi.SyncExecutionInternal
-
Sets whether the execution is currently
interruptable
. - setInterruptable(boolean) - Method in class dev.failsafe.SyncExecutionImpl
- setNext(boolean) - Method in class dev.failsafe.internal.CountingCircuitStats
-
Sets the value of the next bit in the bitset, returning the previous value, else -1 if no previous value was set for the bit.
- setPostExecuted(int) - Method in class dev.failsafe.AsyncExecutionImpl
- setPostExecuted(int) - Method in interface dev.failsafe.spi.AsyncExecutionInternal
-
Sets the PolicyExecutor corresponding to the
policyIndex
as having post-executed. - size - Variable in class dev.failsafe.internal.CountingCircuitStats
- smoothBuilder(long, Duration) - Static method in interface dev.failsafe.RateLimiter
-
Returns a smooth
RateLimiterBuilder
for themaxExecutions
andperiod
, which control how frequently an execution is permitted. - smoothBuilder(Duration) - Static method in interface dev.failsafe.RateLimiter
-
Returns a smooth
RateLimiterBuilder
for themaxRate
, which controls how frequently an execution is permitted. - SmoothRateLimiterStats - Class in dev.failsafe.internal
-
A rate limiter implementation that evenly distributes permits over time, based on the max permits per period.
- SmoothRateLimiterStats(RateLimiterConfig<?>, RateLimiterStats.Stopwatch) - Constructor for class dev.failsafe.internal.SmoothRateLimiterStats
- startTime - Variable in class dev.failsafe.ExecutionImpl
- startTime - Variable in class dev.failsafe.internal.OpenState
- startTime - Variable in class dev.failsafe.internal.RateLimiterStats.Stopwatch
- startTimeMillis - Variable in class dev.failsafe.internal.TimedCircuitStats.Bucket
- Stat() - Constructor for class dev.failsafe.internal.TimedCircuitStats.Stat
- state - Variable in class dev.failsafe.internal.CircuitBreakerImpl
-
Writes guarded by "this"
- state(boolean, String, Object...) - Static method in class dev.failsafe.internal.util.Assert
- State() - Constructor for enum dev.failsafe.CircuitBreaker.State
- stats - Variable in class dev.failsafe.internal.CircuitState
- stats - Variable in class dev.failsafe.internal.RateLimiterImpl
- stopwatch - Variable in class dev.failsafe.internal.RateLimiterStats
- Stopwatch() - Constructor for class dev.failsafe.internal.RateLimiterStats.Stopwatch
- success - Variable in class dev.failsafe.spi.ExecutionResult
-
Whether a policy determined the execution to be a success
- success(R) - Static method in class dev.failsafe.spi.ExecutionResult
-
Returns an ExecutionResult with the
result
set,complete
true andsuccess
true. - successAll - Variable in class dev.failsafe.spi.ExecutionResult
-
Whether all policies determined the execution to be a success
- successes - Variable in class dev.failsafe.internal.CountingCircuitStats
- successes - Variable in class dev.failsafe.internal.TimedCircuitStats.Stat
- successHandler - Variable in class dev.failsafe.FailsafeExecutor
- successHandler - Variable in class dev.failsafe.spi.PolicyExecutor
- successListener - Variable in class dev.failsafe.PolicyConfig
- successThreshold - Variable in class dev.failsafe.CircuitBreakerConfig
- successThresholdingCapacity - Variable in class dev.failsafe.CircuitBreakerConfig
- summary - Variable in class dev.failsafe.internal.TimedCircuitStats
- SyncExecutionImpl<R> - Class in dev.failsafe
-
SyncExecution and SyncExecutionInternal implementation.
- SyncExecutionImpl(FailsafeExecutor<R>, Scheduler, CallImpl<R>, Function<SyncExecutionInternal<R>, ExecutionResult<R>>) - Constructor for class dev.failsafe.SyncExecutionImpl
-
Create a sync execution for the
executor
. - SyncExecutionImpl(SyncExecutionImpl<R>) - Constructor for class dev.failsafe.SyncExecutionImpl
-
Create a sync execution for a new attempt.
- SyncExecutionImpl(List<? extends Policy<R>>) - Constructor for class dev.failsafe.SyncExecutionImpl
-
Create a standalone sync execution for the
policies
. - SyncExecutionInternal<R> - Interface in dev.failsafe.spi
-
Internal execution APIs.
T
- tail - Variable in class dev.failsafe.internal.util.FutureLinkedList
- test(T) - Method in interface dev.failsafe.function.CheckedPredicate
- test(T, U) - Method in interface dev.failsafe.function.CheckedBiPredicate
- time - Variable in class dev.failsafe.internal.util.DelegatingScheduler.ScheduledCompletableFuture
- TimedCircuitStats - Class in dev.failsafe.internal
-
A CircuitStats implementation that counts execution results within a time period, and buckets results to minimize overhead.
- TimedCircuitStats(int, Duration, TimedCircuitStats.Clock, CircuitStats) - Constructor for class dev.failsafe.internal.TimedCircuitStats
- TimedCircuitStats.Bucket - Class in dev.failsafe.internal
- TimedCircuitStats.Clock - Class in dev.failsafe.internal
- TimedCircuitStats.Stat - Class in dev.failsafe.internal
- timeout - Variable in class dev.failsafe.TimeoutConfig
- timeout - Variable in exception dev.failsafe.TimeoutExceededException
- Timeout<R> - Interface in dev.failsafe
-
A policy that cancels and fails an excecution with a
TimeoutExceededException
if a timeout is exceeded. - TimeoutBuilder<R> - Class in dev.failsafe
-
Builds
Timeout
instances. - TimeoutBuilder(TimeoutConfig<R>) - Constructor for class dev.failsafe.TimeoutBuilder
- TimeoutBuilder(Duration) - Constructor for class dev.failsafe.TimeoutBuilder
- TimeoutConfig<R> - Class in dev.failsafe
-
Configuration for a
Timeout
. - TimeoutConfig(TimeoutConfig<R>) - Constructor for class dev.failsafe.TimeoutConfig
- TimeoutConfig(Duration, boolean) - Constructor for class dev.failsafe.TimeoutConfig
- TimeoutExceededException - Exception in dev.failsafe
-
Thrown when an execution exceeds a configured
Timeout
. - TimeoutExceededException(Timeout<?>) - Constructor for exception dev.failsafe.TimeoutExceededException
- TimeoutExecutor<R> - Class in dev.failsafe.internal
-
A PolicyExecutor that handles failures according to a
Timeout
. - TimeoutExecutor(TimeoutImpl<R>, int) - Constructor for class dev.failsafe.internal.TimeoutExecutor
- TimeoutImpl<R> - Class in dev.failsafe.internal
-
A
Timeout
implementation. - TimeoutImpl(TimeoutConfig<R>) - Constructor for class dev.failsafe.internal.TimeoutImpl
- toAsync(Function<AsyncExecutionInternal<R>, CompletableFuture<ExecutionResult<R>>>, Scheduler, FailsafeFuture<R>) - Static method in class dev.failsafe.Functions
-
Returns a Function that asynchronously applies the
innerFn
on the first call, synchronously on subsequent calls, and returns a promise containing the result. - toCtxSupplier(CheckedRunnable) - Static method in class dev.failsafe.Functions
- toCtxSupplier(CheckedSupplier<T>) - Static method in class dev.failsafe.Functions
- toCtxSupplier(ContextualRunnable<Void>) - Static method in class dev.failsafe.Functions
- toExecutionAware(Function<AsyncExecutionInternal<R>, CompletableFuture<ExecutionResult<R>>>) - Static method in class dev.failsafe.Functions
-
Returns a Function that returns an execution result if one was previously recorded, else applies the
innerFn
. - toExecutor(int) - Method in class dev.failsafe.internal.BulkheadImpl
- toExecutor(int) - Method in class dev.failsafe.internal.CircuitBreakerImpl
- toExecutor(int) - Method in class dev.failsafe.internal.FallbackImpl
- toExecutor(int) - Method in class dev.failsafe.internal.RateLimiterImpl
- toExecutor(int) - Method in class dev.failsafe.internal.RetryPolicyImpl
- toExecutor(int) - Method in class dev.failsafe.internal.TimeoutImpl
- toExecutor(int) - Method in interface dev.failsafe.Policy
-
Returns a
PolicyExecutor
capable of handling an execution for the Policy. - toFn(CheckedConsumer<T>) - Static method in class dev.failsafe.Functions
- toFn(CheckedRunnable) - Static method in class dev.failsafe.Functions
- toFn(CheckedSupplier<? extends R>) - Static method in class dev.failsafe.Functions
- toFn(R) - Static method in class dev.failsafe.Functions
- toString() - Method in class dev.failsafe.event.ExecutionAttemptedEvent
- toString() - Method in class dev.failsafe.event.ExecutionCompletedEvent
- toString() - Method in class dev.failsafe.event.ExecutionScheduledEvent
- toString() - Method in class dev.failsafe.ExecutionImpl
- toString() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- toString() - Method in class dev.failsafe.internal.CountingCircuitStats
-
Returns an array representation of the BitSet entries.
- toString() - Method in class dev.failsafe.internal.TimedCircuitStats.Bucket
- toString() - Method in class dev.failsafe.internal.TimedCircuitStats.Stat
- toString() - Method in class dev.failsafe.internal.TimedCircuitStats
- toString() - Method in class dev.failsafe.internal.TimeoutImpl
- toString() - Method in class dev.failsafe.spi.ExecutionResult
- transitionTo(CircuitBreaker.State, EventListener<CircuitBreakerStateChangedEvent>, ExecutionContext<R>) - Method in class dev.failsafe.internal.CircuitBreakerImpl
-
Transitions to the
newState
if not already in that state and calls any associated event listener. - tryAcquirePermit() - Method in interface dev.failsafe.Bulkhead
-
Tries to acquire a permit to perform an execution within the bulkhead, returning immediately without waiting.
- tryAcquirePermit() - Method in interface dev.failsafe.CircuitBreaker
-
Tries to acquire a permit to use the circuit breaker and returns whether a permit was acquired.
- tryAcquirePermit() - Method in class dev.failsafe.internal.BulkheadImpl
- tryAcquirePermit() - Method in class dev.failsafe.internal.CircuitBreakerImpl
- tryAcquirePermit() - Method in class dev.failsafe.internal.CircuitState
- tryAcquirePermit() - Method in class dev.failsafe.internal.ClosedState
- tryAcquirePermit() - Method in class dev.failsafe.internal.HalfOpenState
- tryAcquirePermit() - Method in class dev.failsafe.internal.OpenState
- tryAcquirePermit() - Method in interface dev.failsafe.RateLimiter
-
Tries to acquire a permit to perform an execution against the rate limiter, returning immediately without waiting.
- tryAcquirePermit(Duration) - Method in interface dev.failsafe.Bulkhead
-
Tries to acquire a permit to perform an execution within the bulkhead, waiting up to the
maxWaitTime
until they are available. - tryAcquirePermit(Duration) - Method in class dev.failsafe.internal.BulkheadImpl
- tryAcquirePermit(Duration) - Method in interface dev.failsafe.RateLimiter
-
Tries to acquire a permit to perform an execution against the rate limiter, waiting up to the
maxWaitTime
until they are available. - tryAcquirePermits(int) - Method in class dev.failsafe.internal.RateLimiterImpl
- tryAcquirePermits(int) - Method in interface dev.failsafe.RateLimiter
-
Tries to acquire the requested
permits
to perform executions against the rate limiter, returning immediately without waiting. - tryAcquirePermits(int, Duration) - Method in class dev.failsafe.internal.RateLimiterImpl
- tryAcquirePermits(int, Duration) - Method in interface dev.failsafe.RateLimiter
-
Tries to acquire the requested
permits
to perform executions against the rate limiter, waiting up to themaxWaitTime
until they are available. - tryReservePermit(Duration) - Method in interface dev.failsafe.RateLimiter
-
Tries to reserve a permit to perform an execution against the rate limiter, and returns the time that the caller is expected to wait before acting on the permit, as long as it's less than the
maxWaitTime
. - tryReservePermits(int, Duration) - Method in class dev.failsafe.internal.RateLimiterImpl
- tryReservePermits(int, Duration) - Method in interface dev.failsafe.RateLimiter
-
Tries to reserve the
permits
to perform executions against the rate limiter, and returns the time that the caller is expected to wait before acting on the permits, as long as it's less than themaxWaitTime
.
V
- valueOf(String) - Static method in enum dev.failsafe.CircuitBreaker.State
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum dev.failsafe.CircuitBreaker.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
W
- windowSizeMillis - Variable in class dev.failsafe.internal.TimedCircuitStats
- with(long, boolean, boolean) - Method in class dev.failsafe.spi.ExecutionResult
-
Returns a copy of the ExecutionResult with the
delayNanos
,complete
andsuccess
values. - with(Scheduler) - Method in class dev.failsafe.FailsafeExecutor
-
Configures the
scheduler
to use for performing asynchronous executions and listener callbacks. - with(Executor) - Method in class dev.failsafe.FailsafeExecutor
-
Configures the
executor
to use as a wrapper around executions. - with(ExecutorService) - Method in class dev.failsafe.FailsafeExecutor
-
Configures the
executorService
to use for performing asynchronous executions and listener callbacks. - with(ScheduledExecutorService) - Method in class dev.failsafe.FailsafeExecutor
-
Configures the
scheduledExecutorService
to use for performing asynchronous executions and listener callbacks. - with(List<? extends Policy<R>>) - Static method in class dev.failsafe.Failsafe
-
Creates and returns a new
FailsafeExecutor
instance that will handle failures according to the givenpolicies
. - with(P, P...) - Static method in class dev.failsafe.Failsafe
-
Creates and returns a new
FailsafeExecutor
instance that will handle failures according to the givenouterPolicy
andpolicies
. - withAsync() - Method in class dev.failsafe.FallbackBuilder
-
Configures the fallback to run asynchronously.
- withBackoff(long, long, ChronoUnit) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the
delay
between retries, exponentially backing off to themaxDelay
and multiplying consecutive delays by a factor of 2. - withBackoff(long, long, ChronoUnit, double) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the
delay
between retries, exponentially backing off to themaxDelay
and multiplying consecutive delays by thedelayFactor
. - withBackoff(Duration, Duration) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the
delay
between retries, exponentially backing off to themaxDelay
and multiplying consecutive delays by a factor of 2. - withBackoff(Duration, Duration, double) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the
delay
between retries, exponentially backing off to themaxDelay
and multiplying consecutive delays by thedelayFactor
. - withDelay(long) - Method in class dev.failsafe.spi.ExecutionResult
-
Returns a copy of the ExecutionResult with the
delayNanos
value. - withDelay(long, long, ChronoUnit) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets a random delay between the
delayMin
anddelayMax
(inclusive) to occur between retries. - withDelay(Duration) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Sets the
delay
to wait in OPEN state before transitioning to half-open. - withDelay(Duration) - Method in class dev.failsafe.DelayablePolicyBuilder
-
Sets the
delay
to occur between execution attempts. - withDelay(Duration) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the fixed
delay
to occur between retries. - withDelay(Duration, Duration) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets a random delay between the
delayMin
anddelayMax
(inclusive) to occur between retries. - withDelayFn(ContextualSupplier<R, Duration>) - Method in class dev.failsafe.DelayablePolicyBuilder
-
Sets the
delayFunction
that computes the next delay before allowing another execution. - withDelayFnOn(ContextualSupplier<R, Duration>, Class<F>) - Method in class dev.failsafe.DelayablePolicyBuilder
-
Sets the
delayFunction
that computes the next delay before allowing another execution. - withDelayFnWhen(ContextualSupplier<R, Duration>, R) - Method in class dev.failsafe.DelayablePolicyBuilder
-
Sets the
delayFunction
that computes the next delay before allowing another execution. - withException() - Method in class dev.failsafe.spi.ExecutionResult
-
Returns a copy of the ExecutionResult with success value of {code false}.
- withExecutor(AsyncRunnable<R>, Executor) - Static method in class dev.failsafe.Functions
- withExecutor(ContextualSupplier<R, T>, Executor) - Static method in class dev.failsafe.Functions
- withFailureRateThreshold(int, int, Duration) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Configures time based failure rate thresholding by setting the percentage rate of failures, from 1 to 100, that must occur within the rolling
failureThresholdingPeriod
when in a CLOSED state in order to open the circuit. - withFailureThreshold(int) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Configures count based failure thresholding by setting the number of consecutive failures that must occur when in a CLOSED state in order to open the circuit.
- withFailureThreshold(int, int) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Configures count based failure thresholding by setting the ratio of failures to executions that must occur when in a CLOSED state in order to open the circuit.
- withFailureThreshold(int, int, Duration) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Configures time based failure thresholding by setting the number of failures that must occur within the
failureThresholdingPeriod
when in a CLOSED state in order to open the circuit. - withFailureThreshold(int, Duration) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Configures time based failure thresholding by setting the number of failures that must occur within the
failureThresholdingPeriod
when in a CLOSED state in order to open the circuit. - withInterrupt() - Method in class dev.failsafe.TimeoutBuilder
-
Configures the policy to interrupt an execution in addition to cancelling it when the timeout is exceeded.
- withJitter(double) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the
jitterFactor
to randomly vary retry delays by. - withJitter(Duration) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the
jitter
to randomly vary retry delays by. - withMaxAttempts(int) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the max number of execution attempts to perform.
- withMaxDuration(Duration) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the max duration to perform retries for, else the execution will be failed.
- withMaxRetries(int) - Method in class dev.failsafe.RetryPolicyBuilder
-
Sets the max number of retries to perform when an execution attempt fails.
- withMaxWaitTime(Duration) - Method in class dev.failsafe.BulkheadBuilder
-
Configures the
maxWaitTime
to wait for permits to be available. - withMaxWaitTime(Duration) - Method in class dev.failsafe.RateLimiterBuilder
-
Configures the
maxWaitTime
to wait for permits to be available. - withNonResult() - Method in class dev.failsafe.spi.ExecutionResult
-
Returns a copy of the ExecutionResult with a non-result, and complete and success set to true.
- withNotComplete() - Method in class dev.failsafe.spi.ExecutionResult
-
Returns a copy of the ExecutionResult with
complete
set to false, else this if nothing has changed. - withResult(R) - Method in class dev.failsafe.spi.ExecutionResult
-
Returns a copy of the ExecutionResult with the
result
value, and complete and success set to true. - withSuccess() - Method in class dev.failsafe.spi.ExecutionResult
-
Returns a copy of the ExecutionResult with the
complete
andsuccess
values oftrue
. - withSuccessThreshold(int) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Configures count based success thresholding by setting the number of consecutive successful executions that must occur when in a HALF_OPEN state in order to close the circuit, else the circuit is re-opened when a failure occurs.
- withSuccessThreshold(int, int) - Method in class dev.failsafe.CircuitBreakerBuilder
-
Configures count based success thresholding by setting the ratio of successful executions that must occur when in a HALF_OPEN state in order to close the circuit.
All Classes All Packages