Skip navigation links
A B C D F G I L M O P R S T V W 

A

AbstractRateLimiterEvent - Class in io.github.robwin.ratelimiter.event
 
AbstractRateLimiterEvent(String) - Constructor for class io.github.robwin.ratelimiter.event.AbstractRateLimiterEvent
 
accept(T) - Method in class io.github.robwin.consumer.CircularEventConsumer
 
add(T) - Method in interface io.github.robwin.circularbuffer.CircularFifoBuffer
Adds element to the CircularFifoBuffer and overwrites the oldest element when CircularFifoBuffer.isFull().
add(T) - Method in class io.github.robwin.circularbuffer.ConcurrentCircularFifoBuffer
Adds element to the CircularFifoBuffer and overwrites the oldest element when CircularFifoBuffer.isFull().
apply(Subscriber<? super T>) - Method in class io.github.robwin.circuitbreaker.operator.CircuitBreakerOperator
 
apply(Observer<? super T>) - Method in class io.github.robwin.circuitbreaker.operator.CircuitBreakerOperator
 
apply(SingleObserver<? super T>) - Method in class io.github.robwin.circuitbreaker.operator.CircuitBreakerOperator
 
AtomicRateLimiter - Class in io.github.robwin.ratelimiter.internal
AtomicRateLimiter splits all nanoseconds from the start of epoch into cycles.
AtomicRateLimiter(String, RateLimiterConfig) - Constructor for class io.github.robwin.ratelimiter.internal.AtomicRateLimiter
 
AtomicRateLimiter.AtomicRateLimiterMetrics - Class in io.github.robwin.ratelimiter.internal
Enhanced Metrics with some implementation specific details

B

backoffFunction(Function<Duration, Duration>) - Method in class io.github.robwin.retry.RetryConfig.Builder
Set a function to modify the waiting interval after a failure.
build() - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig.Builder
Builds a CircuitBreakerConfig
build() - Method in class io.github.robwin.ratelimiter.RateLimiterConfig.Builder
Builds a RateLimiterConfig
build() - Method in class io.github.robwin.retry.RetryConfig.Builder
 
Builder() - Constructor for class io.github.robwin.circuitbreaker.CircuitBreakerConfig.Builder
 
Builder() - Constructor for class io.github.robwin.ratelimiter.RateLimiterConfig.Builder
 
Builder() - Constructor for class io.github.robwin.retry.RetryConfig.Builder
 

C

Cache<K,V> - Interface in io.github.robwin.cache
 
CacheContext<K,V> - Class in io.github.robwin.cache.internal
 
CacheContext(Cache<K, V>) - Constructor for class io.github.robwin.cache.internal.CacheContext
 
CacheEvent - Interface in io.github.robwin.cache.event
An event which is created by a CircuitBreaker.
CacheEvent.Type - Enum in io.github.robwin.cache.event
Event types which are created by a CircuitBreaker.
CacheOnErrorEvent - Class in io.github.robwin.cache.event
A CacheEvent which informs that accessing the cache has caused an exception.
CacheOnErrorEvent(String, Throwable) - Constructor for class io.github.robwin.cache.event.CacheOnErrorEvent
 
CacheOnHitEvent<K> - Class in io.github.robwin.cache.event
A CacheEvent which informs about a cache hit.
CacheOnHitEvent(String, K) - Constructor for class io.github.robwin.cache.event.CacheOnHitEvent
 
CacheOnMissEvent<K> - Class in io.github.robwin.cache.event
A CacheEvent which informs about a cache miss.
CacheOnMissEvent(String, K) - Constructor for class io.github.robwin.cache.event.CacheOnMissEvent
 
CircuitBreaker - Interface in io.github.robwin.circuitbreaker
A CircuitBreaker manages the state of a backend system.
circuitBreaker(String) - Method in interface io.github.robwin.circuitbreaker.CircuitBreakerRegistry
Returns a managed CircuitBreaker or creates a new one with the default CircuitBreaker configuration.
circuitBreaker(String, CircuitBreakerConfig) - Method in interface io.github.robwin.circuitbreaker.CircuitBreakerRegistry
Returns a managed CircuitBreaker or creates a new one with a custom CircuitBreaker configuration.
circuitBreaker(String, Supplier<CircuitBreakerConfig>) - Method in interface io.github.robwin.circuitbreaker.CircuitBreakerRegistry
Returns a managed CircuitBreaker or creates a new one with a custom CircuitBreaker configuration.
circuitBreaker(String) - Method in class io.github.robwin.circuitbreaker.internal.InMemoryCircuitBreakerRegistry
Returns a managed CircuitBreaker or creates a new one with the default CircuitBreaker configuration.
circuitBreaker(String, CircuitBreakerConfig) - Method in class io.github.robwin.circuitbreaker.internal.InMemoryCircuitBreakerRegistry
Returns a managed CircuitBreaker or creates a new one with a custom CircuitBreaker configuration.
circuitBreaker(String, Supplier<CircuitBreakerConfig>) - Method in class io.github.robwin.circuitbreaker.internal.InMemoryCircuitBreakerRegistry
 
CircuitBreaker.Metrics - Interface in io.github.robwin.circuitbreaker
 
CircuitBreaker.State - Enum in io.github.robwin.circuitbreaker
States of the CircuitBreaker state machine.
CircuitBreaker.StateTransition - Enum in io.github.robwin.circuitbreaker
State transitions of the CircuitBreaker state machine.
CircuitBreakerConfig - Class in io.github.robwin.circuitbreaker
CircuitBreakerConfig.Builder - Class in io.github.robwin.circuitbreaker
 
CircuitBreakerEvent - Interface in io.github.robwin.circuitbreaker.event
An event which is created by a CircuitBreaker.
CircuitBreakerEvent.Type - Enum in io.github.robwin.circuitbreaker.event
Event types which are created by a CircuitBreaker.
CircuitBreakerOnCallNotPermittedEvent - Class in io.github.robwin.circuitbreaker.event
A CircuitBreakerEvent which informs that a call was not permitted, because the CircuitBreaker is OPEN.
CircuitBreakerOnCallNotPermittedEvent(String) - Constructor for class io.github.robwin.circuitbreaker.event.CircuitBreakerOnCallNotPermittedEvent
 
CircuitBreakerOnErrorEvent - Class in io.github.robwin.circuitbreaker.event
A CircuitBreakerEvent which informs that an error has been recorded
CircuitBreakerOnErrorEvent(String, Duration, Throwable) - Constructor for class io.github.robwin.circuitbreaker.event.CircuitBreakerOnErrorEvent
 
CircuitBreakerOnIgnoredErrorEvent - Class in io.github.robwin.circuitbreaker.event
A CircuitBreakerEvent which informs that an error has been ignored
CircuitBreakerOnIgnoredErrorEvent(String, Duration, Throwable) - Constructor for class io.github.robwin.circuitbreaker.event.CircuitBreakerOnIgnoredErrorEvent
 
CircuitBreakerOnStateTransitionEvent - Class in io.github.robwin.circuitbreaker.event
A CircuitBreakerEvent which informs about a state transition.
CircuitBreakerOnStateTransitionEvent(String, CircuitBreaker.StateTransition) - Constructor for class io.github.robwin.circuitbreaker.event.CircuitBreakerOnStateTransitionEvent
 
CircuitBreakerOnSuccessEvent - Class in io.github.robwin.circuitbreaker.event
A CircuitBreakerEvent which informs that a success has been recorded
CircuitBreakerOnSuccessEvent(String, Duration) - Constructor for class io.github.robwin.circuitbreaker.event.CircuitBreakerOnSuccessEvent
 
CircuitBreakerOpenException - Exception in io.github.robwin.circuitbreaker
A CircuitBreakerOpenException signals that the CircuitBreaker is OPEN.
CircuitBreakerOpenException(String) - Constructor for exception io.github.robwin.circuitbreaker.CircuitBreakerOpenException
The constructor with a message.
CircuitBreakerOperator<T> - Class in io.github.robwin.circuitbreaker.operator
A RxJava operator which protects an Observable or Flowable by a CircuitBreaker
CircuitBreakerRegistry - Interface in io.github.robwin.circuitbreaker
The CircuitBreakerRegistry is a factory to create CircuitBreaker instances which stores all CircuitBreaker instances in a registry.
CircuitBreakerStateMachine - Class in io.github.robwin.circuitbreaker.internal
A CircuitBreaker finite state machine.
CircuitBreakerStateMachine(String, CircuitBreakerConfig) - Constructor for class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
Creates a circuitBreaker.
CircuitBreakerStateMachine(String) - Constructor for class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
Creates a circuitBreaker with default config.
CircuitBreakerStateMachine(String, Supplier<CircuitBreakerConfig>) - Constructor for class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
Creates a circuitBreaker.
CircuitBreakerUtils - Class in io.github.robwin.circuitbreaker.utils
 
CircularEventConsumer<T> - Class in io.github.robwin.consumer
A RxJava consumer which stores CircuitBreakerEvents in a circular buffer with a fixed capacity.
CircularEventConsumer(int) - Constructor for class io.github.robwin.consumer.CircularEventConsumer
Creates an CircuitBreakerEventConsumer with the given (fixed) capacity
CircularFifoBuffer<T> - Interface in io.github.robwin.circularbuffer
A CircularFifoBuffer is a first in first out buffer with a fixed size that replaces its oldest element if full.
clear() - Method in class io.github.robwin.circularbuffer.ConcurrentEvictingQueue
Atomically removes all of the elements from this queue.
computeIfAbsent(K, Try.CheckedSupplier<V>) - Method in interface io.github.robwin.cache.Cache
If the key is not already associated with a cached value, attempts to compute its value using the given supplier and puts it into the cache.
computeIfAbsent(K, Try.CheckedSupplier<V>) - Method in class io.github.robwin.cache.internal.CacheContext
 
ConcurrentCircularFifoBuffer<T> - Class in io.github.robwin.circularbuffer
Thread safe implementation of CircularFifoBuffer on top of ConcurrentEvictingQueue
ConcurrentCircularFifoBuffer(int) - Constructor for class io.github.robwin.circularbuffer.ConcurrentCircularFifoBuffer
Creates an ConcurrentCircularFifoBuffer with the given (fixed) capacity
ConcurrentEvictingQueue<E> - Class in io.github.robwin.circularbuffer
The purpose of this queue is to store the N most recently inserted elements.
ConcurrentEvictingQueue(int) - Constructor for class io.github.robwin.circularbuffer.ConcurrentEvictingQueue
 
custom() - Static method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
Returns a builder to create a custom CircuitBreakerConfig.
custom() - Static method in class io.github.robwin.ratelimiter.RateLimiterConfig
Returns a builder to create a custom RateLimiterConfig.
custom() - Static method in class io.github.robwin.retry.RetryConfig
Returns a builder to create a custom RetryConfig.

D

decorate() - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedFunction
 
decorate() - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedRunnable
 
decorate() - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedSupplier
 
decorate() - Method in class io.github.robwin.decorators.Decorators.DecorateFunction
 
decorate() - Method in class io.github.robwin.decorators.Decorators.DecorateRunnable
 
decorate() - Method in class io.github.robwin.decorators.Decorators.DecorateSupplier
 
decorateCallable(Cache<K, R>, Callable<R>) - Static method in interface io.github.robwin.cache.Cache
Creates a functions which returns a value from a cache, if it exists.
decorateCallable(CircuitBreaker, Callable<T>) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a callable which is secured by a CircuitBreaker.
decorateCheckedConsumer(CircuitBreaker, Try.CheckedConsumer<T>) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a consumer which is secured by a CircuitBreaker.
decorateCheckedFunction(CircuitBreaker, Try.CheckedFunction<T, R>) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a function which is secured by a CircuitBreaker.
decorateCheckedFunction(RateLimiter, Try.CheckedFunction<T, R>) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a function which is restricted by a RateLimiter.
decorateCheckedFunction(Retry, Try.CheckedFunction<T, R>) - Static method in interface io.github.robwin.retry.Retry
Creates a retryable function.
decorateCheckedRunnable(CircuitBreaker, Try.CheckedRunnable) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a runnable which is secured by a CircuitBreaker.
decorateCheckedRunnable(RateLimiter, Try.CheckedRunnable) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a runnable which is restricted by a RateLimiter.
decorateCheckedRunnable(Retry, Try.CheckedRunnable) - Static method in interface io.github.robwin.retry.Retry
Creates a retryable runnable.
decorateCheckedSupplier(Cache<K, R>, Try.CheckedSupplier<R>) - Static method in interface io.github.robwin.cache.Cache
Creates a functions which returns a value from a cache, if it exists.
decorateCheckedSupplier(CircuitBreaker, Try.CheckedSupplier<T>) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a supplier which is secured by a CircuitBreaker.
decorateCheckedSupplier(RateLimiter, Try.CheckedSupplier<T>) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a supplier which is restricted by a RateLimiter.
decorateCheckedSupplier(Retry, Try.CheckedSupplier<T>) - Static method in interface io.github.robwin.retry.Retry
Creates a retryable supplier.
decorateConsumer(CircuitBreaker, Consumer<T>) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a consumer which is secured by a CircuitBreaker.
decorateConsumer(RateLimiter, Consumer<T>) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a consumer which is restricted by a RateLimiter.
decorateFunction(CircuitBreaker, Function<T, R>) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a function which is secured by a CircuitBreaker.
decorateFunction(RateLimiter, Function<T, R>) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a function which is restricted by a RateLimiter.
decorateFunction(Retry, Function<T, R>) - Static method in interface io.github.robwin.retry.Retry
Creates a retryable function.
decorateRunnable(CircuitBreaker, Runnable) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a runnable which is secured by a CircuitBreaker.
decorateRunnable(RateLimiter, Runnable) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a runnable which is restricted by a RateLimiter.
decorateRunnable(Retry, Runnable) - Static method in interface io.github.robwin.retry.Retry
Creates a retryable runnable.
decorateSupplier(Cache<K, R>, Supplier<R>) - Static method in interface io.github.robwin.cache.Cache
Creates a functions which returns a value from a cache, if it exists.
decorateSupplier(CircuitBreaker, Supplier<T>) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a supplier which is secured by a CircuitBreaker.
decorateSupplier(RateLimiter, Supplier<T>) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a supplier which is restricted by a RateLimiter.
decorateSupplier(Retry, Supplier<T>) - Static method in interface io.github.robwin.retry.Retry
Creates a retryable supplier.
Decorators - Interface in io.github.robwin.decorators
A Decorator builder which can be used to apply multiple decorators to a (Checked-)Supplier, (Checked-)Function or (Checked-)Runnable.
Decorators.DecorateCheckedFunction<T,R> - Class in io.github.robwin.decorators
 
Decorators.DecorateCheckedRunnable - Class in io.github.robwin.decorators
 
Decorators.DecorateCheckedSupplier<T> - Class in io.github.robwin.decorators
 
Decorators.DecorateFunction<T,R> - Class in io.github.robwin.decorators
 
Decorators.DecorateRunnable - Class in io.github.robwin.decorators
 
Decorators.DecorateSupplier<T> - Class in io.github.robwin.decorators
 
DEFAULT_MAX_ATTEMPTS - Static variable in class io.github.robwin.retry.RetryConfig
 
DEFAULT_MAX_FAILURE_THRESHOLD - Static variable in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 
DEFAULT_RING_BUFFER_SIZE_IN_CLOSED_STATE - Static variable in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 
DEFAULT_RING_BUFFER_SIZE_IN_HALF_OPEN_STATE - Static variable in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 
DEFAULT_WAIT_DURATION - Static variable in class io.github.robwin.retry.RetryConfig
 
DEFAULT_WAIT_DURATION_IN_OPEN_STATE - Static variable in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 

F

failureRateThreshold(int) - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig.Builder
Configures the failure rate threshold in percentage above which the CircuitBreaker should trip open and start short-circuiting calls.

G

getAvailablePermissions() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter.AtomicRateLimiterMetrics
Estimates count of available permissions.
getAvailablePermissions() - Method in class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter.SemaphoreBasedRateLimiterMetrics
Estimates count of available permissions.
getAvailablePermissions() - Method in interface io.github.robwin.ratelimiter.RateLimiter.Metrics
Estimates count of available permissions.
getBackoffFunction() - Method in class io.github.robwin.retry.RetryConfig
 
getBufferedEvents() - Method in class io.github.robwin.consumer.CircularEventConsumer
Returns a list containing all of the buffered events.
getCacheKey() - Method in class io.github.robwin.cache.event.CacheOnHitEvent
 
getCacheKey() - Method in class io.github.robwin.cache.event.CacheOnMissEvent
 
getCacheName() - Method in interface io.github.robwin.cache.event.CacheEvent
Returns the name of the Cache which has created the event.
getCircuitBreakerConfig() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Returns the CircuitBreakerConfig of this CircuitBreaker.
getCircuitBreakerConfig() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
Get the config of this CircuitBreaker.
getCircuitBreakerName() - Method in interface io.github.robwin.circuitbreaker.event.CircuitBreakerEvent
Returns the name of the CircuitBreaker which has created the event.
getCreationTime() - Method in interface io.github.robwin.cache.event.CacheEvent
Returns the creation time of Cache event.
getCreationTime() - Method in interface io.github.robwin.circuitbreaker.event.CircuitBreakerEvent
Returns the creation time of CircuitBreaker event.
getCreationTime() - Method in class io.github.robwin.ratelimiter.event.AbstractRateLimiterEvent
 
getCreationTime() - Method in interface io.github.robwin.ratelimiter.event.RateLimiterEvent
 
getCreationTime() - Method in interface io.github.robwin.retry.event.RetryEvent
Returns the creation time of Retry event.
getCycle() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter.AtomicRateLimiterMetrics
 
getDetailedMetrics() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter
Get the enhanced Metrics with some implementation specific details.
getElapsedDuration() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnErrorEvent
 
getElapsedDuration() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnIgnoredErrorEvent
 
getElapsedDuration() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnSuccessEvent
 
getEventStream() - Method in interface io.github.robwin.cache.Cache
Returns a reactive stream of CacheEvents.
getEventStream() - Method in class io.github.robwin.cache.internal.CacheContext
 
getEventStream() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Returns a reactive stream of CircuitBreakerEvents.
getEventStream() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
 
getEventStream() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter
Returns a reactive stream of RateLimiter.
getEventStream() - Method in class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter
Returns a reactive stream of RateLimiter.
getEventStream() - Method in interface io.github.robwin.ratelimiter.RateLimiter
Returns a reactive stream of RateLimiter.
getEventStream() - Method in class io.github.robwin.retry.internal.RetryContext
 
getEventStream() - Method in interface io.github.robwin.retry.Retry
Returns a reactive stream of RetryEvents.
getEventType() - Method in interface io.github.robwin.cache.event.CacheEvent
Returns the type of the Cache event.
getEventType() - Method in class io.github.robwin.cache.event.CacheOnErrorEvent
 
getEventType() - Method in class io.github.robwin.cache.event.CacheOnHitEvent
 
getEventType() - Method in class io.github.robwin.cache.event.CacheOnMissEvent
 
getEventType() - Method in interface io.github.robwin.circuitbreaker.event.CircuitBreakerEvent
Returns the type of the CircuitBreaker event.
getEventType() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnCallNotPermittedEvent
 
getEventType() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnErrorEvent
 
getEventType() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnIgnoredErrorEvent
 
getEventType() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnStateTransitionEvent
 
getEventType() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnSuccessEvent
 
getEventType() - Method in class io.github.robwin.ratelimiter.event.AbstractRateLimiterEvent
 
getEventType() - Method in interface io.github.robwin.ratelimiter.event.RateLimiterEvent
 
getEventType() - Method in class io.github.robwin.ratelimiter.event.RateLimiterOnFailureEvent
 
getEventType() - Method in class io.github.robwin.ratelimiter.event.RateLimiterOnSuccessEvent
 
getEventType() - Method in interface io.github.robwin.retry.event.RetryEvent
Returns the type of the Retry event.
getEventType() - Method in class io.github.robwin.retry.event.RetryOnErrorEvent
 
getEventType() - Method in class io.github.robwin.retry.event.RetryOnSuccessEvent
 
getExceptionPredicate() - Method in class io.github.robwin.retry.RetryConfig
 
getFailureRate() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker.Metrics
Returns the failure rate in percentage.
getFailureRateThreshold() - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 
getFromState() - Method in enum io.github.robwin.circuitbreaker.CircuitBreaker.StateTransition
 
getId() - Method in class io.github.robwin.metrics.StopWatch
 
getId() - Method in interface io.github.robwin.retry.event.RetryEvent
Returns the ID of the Retry.
getId() - Method in class io.github.robwin.retry.internal.RetryContext
 
getId() - Method in interface io.github.robwin.retry.Retry
Returns the ID of this Retry.
getLastThrowable() - Method in interface io.github.robwin.retry.event.RetryEvent
Returns the last captured Throwable.
getLimitForPeriod() - Method in class io.github.robwin.ratelimiter.RateLimiterConfig
 
getLimitRefreshPeriod() - Method in class io.github.robwin.ratelimiter.RateLimiterConfig
 
getMaxAttempts() - Method in class io.github.robwin.retry.RetryConfig
 
getMaxNumberOfBufferedCalls() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker.Metrics
Returns the maximum number of buffered calls.
getMetrics() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Returns the Metrics of this CircuitBreaker.
getMetrics() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
 
getMetrics() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter
Get the Metrics of this RateLimiter.
getMetrics() - Method in class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter
Get the Metrics of this RateLimiter.
getMetrics() - Method in interface io.github.robwin.ratelimiter.RateLimiter
Get the Metrics of this RateLimiter.
getName() - Method in interface io.github.robwin.cache.Cache
Return the cache name.
getName() - Method in class io.github.robwin.cache.internal.CacheContext
 
getName() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Returns the name of this CircuitBreaker.
getName() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
Get the name of this CircuitBreaker.
getName() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter
Get the name of this RateLimiter
getName() - Method in class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter
Get the name of this RateLimiter
getName() - Method in interface io.github.robwin.ratelimiter.RateLimiter
Get the name of this RateLimiter
getNanosToWait() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter.AtomicRateLimiterMetrics
 
getNumberOfAttempts() - Method in interface io.github.robwin.retry.event.RetryEvent
Returns the number of attempts.
getNumberOfBufferedCalls() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker.Metrics
Returns the current number of buffered calls.
getNumberOfFailedCalls() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker.Metrics
Returns the current number of failed calls.
getNumberOfNotPermittedCalls() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker.Metrics
Returns the current number of not permitted calls, when the state is OPEN.
getNumberOfSuccessfulCalls() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker.Metrics
Returns the maximum number of successful calls.
getNumberOfWaitingThreads() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter.AtomicRateLimiterMetrics
Returns an estimate of the number of threads waiting for permission in this JVM process.
getNumberOfWaitingThreads() - Method in class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter.SemaphoreBasedRateLimiterMetrics
Returns an estimate of the number of threads waiting for permission in this JVM process.
getNumberOfWaitingThreads() - Method in interface io.github.robwin.ratelimiter.RateLimiter.Metrics
Returns an estimate of the number of threads waiting for permission in this JVM process.
getPermission(Duration) - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter
Acquires a permission from this rate limiter, blocking until one is available.
getPermission(Duration) - Method in class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter
Acquires a permission from this rate limiter, blocking until one is available.
getPermission(Duration) - Method in interface io.github.robwin.ratelimiter.RateLimiter
Acquires a permission from this rate limiter, blocking until one is available.
getProcessingDuration() - Method in class io.github.robwin.metrics.StopWatch
 
getRateLimiterConfig() - Method in class io.github.robwin.ratelimiter.internal.AtomicRateLimiter
Get the RateLimiterConfig of this RateLimiter.
getRateLimiterConfig() - Method in class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter
Get the RateLimiterConfig of this RateLimiter.
getRateLimiterConfig() - Method in interface io.github.robwin.ratelimiter.RateLimiter
Get the RateLimiterConfig of this RateLimiter.
getRateLimiterName() - Method in class io.github.robwin.ratelimiter.event.AbstractRateLimiterEvent
 
getRateLimiterName() - Method in interface io.github.robwin.ratelimiter.event.RateLimiterEvent
 
getRecordFailurePredicate() - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 
getRingBufferSizeInClosedState() - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 
getRingBufferSizeInHalfOpenState() - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 
getState() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Returns the state of this CircuitBreaker.
getState() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
Get the state of this CircuitBreaker.
getStateTransition() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnStateTransitionEvent
 
getThrowable() - Method in class io.github.robwin.cache.event.CacheOnErrorEvent
 
getThrowable() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnErrorEvent
 
getThrowable() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnIgnoredErrorEvent
 
getTimeoutDuration() - Method in class io.github.robwin.ratelimiter.RateLimiterConfig
 
getToState() - Method in enum io.github.robwin.circuitbreaker.CircuitBreaker.StateTransition
 
getWaitDuration() - Method in class io.github.robwin.retry.RetryConfig
 
getWaitDurationInOpenState() - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
 

I

InMemoryCircuitBreakerRegistry - Class in io.github.robwin.circuitbreaker.internal
Backend circuitBreaker manager.
InMemoryCircuitBreakerRegistry() - Constructor for class io.github.robwin.circuitbreaker.internal.InMemoryCircuitBreakerRegistry
The constructor with default circuitBreaker properties.
InMemoryCircuitBreakerRegistry(CircuitBreakerConfig) - Constructor for class io.github.robwin.circuitbreaker.internal.InMemoryCircuitBreakerRegistry
The constructor with custom default circuitBreaker properties.
InMemoryRateLimiterRegistry - Class in io.github.robwin.ratelimiter.internal
Backend RateLimiter manager.
InMemoryRateLimiterRegistry(RateLimiterConfig) - Constructor for class io.github.robwin.ratelimiter.internal.InMemoryRateLimiterRegistry
 
io.github.robwin.cache - package io.github.robwin.cache
 
io.github.robwin.cache.event - package io.github.robwin.cache.event
 
io.github.robwin.cache.internal - package io.github.robwin.cache.internal
 
io.github.robwin.circuitbreaker - package io.github.robwin.circuitbreaker
 
io.github.robwin.circuitbreaker.event - package io.github.robwin.circuitbreaker.event
 
io.github.robwin.circuitbreaker.internal - package io.github.robwin.circuitbreaker.internal
 
io.github.robwin.circuitbreaker.operator - package io.github.robwin.circuitbreaker.operator
 
io.github.robwin.circuitbreaker.utils - package io.github.robwin.circuitbreaker.utils
 
io.github.robwin.circularbuffer - package io.github.robwin.circularbuffer
 
io.github.robwin.consumer - package io.github.robwin.consumer
 
io.github.robwin.decorators - package io.github.robwin.decorators
 
io.github.robwin.metrics - package io.github.robwin.metrics
 
io.github.robwin.ratelimiter - package io.github.robwin.ratelimiter
 
io.github.robwin.ratelimiter.event - package io.github.robwin.ratelimiter.event
 
io.github.robwin.ratelimiter.internal - package io.github.robwin.ratelimiter.internal
 
io.github.robwin.retry - package io.github.robwin.retry
 
io.github.robwin.retry.event - package io.github.robwin.retry.event
 
io.github.robwin.retry.internal - package io.github.robwin.retry.internal
 
isCallPermitted() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Requests permission to call this circuitBreaker's backend.
isCallPermitted() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
Requests permission to call this backend.
isCallPermitted(CircuitBreaker) - Static method in class io.github.robwin.circuitbreaker.utils.CircuitBreakerUtils
 
isEmpty() - Method in interface io.github.robwin.circularbuffer.CircularFifoBuffer
Returns true if this CircularFifoBuffer contains no elements.
isEmpty() - Method in class io.github.robwin.circularbuffer.ConcurrentCircularFifoBuffer
Returns true if this CircularFifoBuffer contains no elements.
isFull() - Method in interface io.github.robwin.circularbuffer.CircularFifoBuffer
Returns true if this CircularFifoBuffer is full.
isFull() - Method in class io.github.robwin.circularbuffer.ConcurrentCircularFifoBuffer
Returns true if this CircularFifoBuffer is full.
iterator() - Method in class io.github.robwin.circularbuffer.ConcurrentEvictingQueue
Returns an iterator over the elements in this queue in proper sequence.

L

limitForPeriod(int) - Method in class io.github.robwin.ratelimiter.RateLimiterConfig.Builder
Configures the permissions limit for refresh period.
limitRefreshPeriod(Duration) - Method in class io.github.robwin.ratelimiter.RateLimiterConfig.Builder
Configures the period of limit refresh.

M

maxAttempts(int) - Method in class io.github.robwin.retry.RetryConfig.Builder
 

O

of(Cache<K, V>) - Static method in interface io.github.robwin.cache.Cache
Creates a Retry with default configuration.
of(String, CircuitBreakerConfig) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a CircuitBreaker with a custom CircuitBreaker configuration.
of(String, Supplier<CircuitBreakerConfig>) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a CircuitBreaker with a custom CircuitBreaker configuration.
of(CircuitBreakerConfig) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreakerRegistry
Creates a CircuitBreakerRegistry with a custom CircuitBreaker configuration.
of(CircuitBreaker) - Static method in class io.github.robwin.circuitbreaker.operator.CircuitBreakerOperator
Creates a CircuitBreakerOperator.
of(String, RateLimiterConfig) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a RateLimiter with a custom RateLimiter configuration.
of(String, Supplier<RateLimiterConfig>) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a RateLimiter with a custom RateLimiterConfig configuration.
of(RateLimiterConfig) - Static method in interface io.github.robwin.ratelimiter.RateLimiterRegistry
 
of(String, RetryConfig) - Static method in interface io.github.robwin.retry.Retry
Creates a Retry with a custom Retry configuration.
of(String, Supplier<RetryConfig>) - Static method in interface io.github.robwin.retry.Retry
Creates a Retry with a custom Retry configuration.
ofCheckedFunction(Try.CheckedFunction<T, R>) - Static method in interface io.github.robwin.decorators.Decorators
 
ofCheckedRunnable(Try.CheckedRunnable) - Static method in interface io.github.robwin.decorators.Decorators
 
ofCheckedSupplier(Try.CheckedSupplier<T>) - Static method in interface io.github.robwin.decorators.Decorators
 
ofDefaults(String) - Static method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Creates a CircuitBreaker with a default CircuitBreaker configuration.
ofDefaults() - Static method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig
Creates a default CircuitBreaker configuration.
ofDefaults() - Static method in interface io.github.robwin.circuitbreaker.CircuitBreakerRegistry
Creates a CircuitBreakerRegistry with a default CircuitBreaker configuration.
ofDefaults(String) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Creates a RateLimiter with a default RateLimiterConfig configuration.
ofDefaults() - Static method in class io.github.robwin.ratelimiter.RateLimiterConfig
Creates a default RateLimiter configuration.
ofDefaults(String) - Static method in interface io.github.robwin.retry.Retry
Creates a Retry with default configuration.
ofDefaults() - Static method in class io.github.robwin.retry.RetryConfig
Creates a default Retry configuration.
offer(E) - Method in class io.github.robwin.circularbuffer.ConcurrentEvictingQueue
Inserts the specified element at the tail of this queue if it is possible to do so immediately or if capacity limit is exited the oldest element (the head) will be evicted, and then the new element added at the tail.
ofFunction(Function<T, R>) - Static method in interface io.github.robwin.decorators.Decorators
 
ofRunnable(Runnable) - Static method in interface io.github.robwin.decorators.Decorators
 
ofSupplier(Supplier<T>) - Static method in interface io.github.robwin.decorators.Decorators
 
onError(Duration, Throwable) - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Records a failed call.
onError(Duration, Throwable) - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
 
onError(Exception) - Method in class io.github.robwin.retry.internal.RetryContext
 
onError(Exception) - Method in interface io.github.robwin.retry.Retry
Handles a checked exception
onRuntimeError(RuntimeException) - Method in class io.github.robwin.retry.internal.RetryContext
 
onRuntimeError(RuntimeException) - Method in interface io.github.robwin.retry.Retry
Handles a runtime exception
onSuccess(Duration) - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Records a successful call.
onSuccess(Duration) - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
 
onSuccess() - Method in class io.github.robwin.retry.internal.RetryContext
 
onSuccess() - Method in interface io.github.robwin.retry.Retry
Records a successful call.

P

peek() - Method in class io.github.robwin.circularbuffer.ConcurrentEvictingQueue
poll() - Method in class io.github.robwin.circularbuffer.ConcurrentEvictingQueue

R

rateLimiter(String) - Method in class io.github.robwin.ratelimiter.internal.InMemoryRateLimiterRegistry
Returns a managed RateLimiter or creates a new one with the default RateLimiter configuration.
rateLimiter(String, RateLimiterConfig) - Method in class io.github.robwin.ratelimiter.internal.InMemoryRateLimiterRegistry
Returns a managed RateLimiter or creates a new one with a custom RateLimiter configuration.
rateLimiter(String, Supplier<RateLimiterConfig>) - Method in class io.github.robwin.ratelimiter.internal.InMemoryRateLimiterRegistry
Returns a managed RateLimiterConfig or creates a new one with a custom RateLimiterConfig configuration.
RateLimiter - Interface in io.github.robwin.ratelimiter
A RateLimiter distributes permits at a configurable rate.
rateLimiter(String) - Method in interface io.github.robwin.ratelimiter.RateLimiterRegistry
Returns a managed RateLimiter or creates a new one with the default RateLimiter configuration.
rateLimiter(String, RateLimiterConfig) - Method in interface io.github.robwin.ratelimiter.RateLimiterRegistry
Returns a managed RateLimiter or creates a new one with a custom RateLimiter configuration.
rateLimiter(String, Supplier<RateLimiterConfig>) - Method in interface io.github.robwin.ratelimiter.RateLimiterRegistry
Returns a managed RateLimiterConfig or creates a new one with a custom RateLimiterConfig configuration.
RateLimiter.Metrics - Interface in io.github.robwin.ratelimiter
 
RateLimiterConfig - Class in io.github.robwin.ratelimiter
 
RateLimiterConfig.Builder - Class in io.github.robwin.ratelimiter
 
RateLimiterEvent - Interface in io.github.robwin.ratelimiter.event
An event which is created by a RateLimiter.
RateLimiterEvent.Type - Enum in io.github.robwin.ratelimiter.event
 
RateLimiterOnFailureEvent - Class in io.github.robwin.ratelimiter.event
 
RateLimiterOnFailureEvent(String) - Constructor for class io.github.robwin.ratelimiter.event.RateLimiterOnFailureEvent
 
RateLimiterOnSuccessEvent - Class in io.github.robwin.ratelimiter.event
 
RateLimiterOnSuccessEvent(String) - Constructor for class io.github.robwin.ratelimiter.event.RateLimiterOnSuccessEvent
 
RateLimiterRegistry - Interface in io.github.robwin.ratelimiter
Manages all RateLimiter instances.
recordFailure(Predicate<? super Throwable>) - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig.Builder
Configures a Predicate which evaluates if an exception should be recorded as a failure and thus increase the failure rate.
RequestNotPermitted - Exception in io.github.robwin.ratelimiter
Exception that indicates that current thread was not able to acquire permission from RateLimiter.
RequestNotPermitted(String) - Constructor for exception io.github.robwin.ratelimiter.RequestNotPermitted
The constructor with a message.
Retry - Interface in io.github.robwin.retry
 
RetryConfig - Class in io.github.robwin.retry
 
RetryConfig.Builder - Class in io.github.robwin.retry
 
RetryContext - Class in io.github.robwin.retry.internal
 
RetryContext(String, RetryConfig) - Constructor for class io.github.robwin.retry.internal.RetryContext
 
RetryEvent - Interface in io.github.robwin.retry.event
An event which is created by Retry.
RetryEvent.Type - Enum in io.github.robwin.retry.event
Event types which are created by a Retry.
RetryOnErrorEvent - Class in io.github.robwin.retry.event
A RetryEvent which informs that a call has been retried, but still failed.
RetryOnErrorEvent(String, int, Throwable) - Constructor for class io.github.robwin.retry.event.RetryOnErrorEvent
 
retryOnException(Predicate<Throwable>) - Method in class io.github.robwin.retry.RetryConfig.Builder
Configures a Predicate which evaluates if an exception should be retried.
RetryOnSuccessEvent - Class in io.github.robwin.retry.event
A RetryEvent which informs that a call has been retried and a retry was successful
RetryOnSuccessEvent(String, int, Throwable) - Constructor for class io.github.robwin.retry.event.RetryOnSuccessEvent
 
ringBufferSizeInClosedState(int) - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig.Builder
Configures the size of the ring buffer when the CircuitBreaker is closed.
ringBufferSizeInHalfOpenState(int) - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig.Builder
Configures the size of the ring buffer when the CircuitBreaker is half open.

S

SemaphoreBasedRateLimiter - Class in io.github.robwin.ratelimiter.internal
A RateLimiter implementation that consists of Semaphore and scheduler that will refresh permissions after each RateLimiterConfig.limitRefreshPeriod.
SemaphoreBasedRateLimiter(String, RateLimiterConfig) - Constructor for class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter
Creates a RateLimiter.
SemaphoreBasedRateLimiter(String, RateLimiterConfig, ScheduledExecutorService) - Constructor for class io.github.robwin.ratelimiter.internal.SemaphoreBasedRateLimiter
Creates a RateLimiter.
SemaphoreBasedRateLimiter.SemaphoreBasedRateLimiterMetrics - Class in io.github.robwin.ratelimiter.internal
size() - Method in interface io.github.robwin.circularbuffer.CircularFifoBuffer
Returns the number of elements in this CircularFifoBuffer.
size() - Method in class io.github.robwin.circularbuffer.ConcurrentCircularFifoBuffer
Returns the number of elements in this CircularFifoBuffer.
size() - Method in class io.github.robwin.circularbuffer.ConcurrentEvictingQueue
Returns the number of elements in this queue.
start(String) - Static method in class io.github.robwin.metrics.StopWatch
 
stop() - Method in class io.github.robwin.metrics.StopWatch
 
StopWatch - Class in io.github.robwin.metrics
A simple StopWatch to measure the processing duration of a call.

T

take() - Method in interface io.github.robwin.circularbuffer.CircularFifoBuffer
Retrieves and removes the head of this queue, or returns Option.None if this queue is empty.
take() - Method in class io.github.robwin.circularbuffer.ConcurrentCircularFifoBuffer
Retrieves and removes the head of this queue, or returns Option.None if this queue is empty.
throwOrSleepAfterRuntimeException() - Method in class io.github.robwin.retry.internal.RetryContext
 
timeoutDuration(Duration) - Method in class io.github.robwin.ratelimiter.RateLimiterConfig.Builder
Configures the default wait for permission duration.
toArray() - Method in class io.github.robwin.circularbuffer.ConcurrentEvictingQueue
Returns an array containing all of the elements in this queue, in proper sequence.
toArray(T[]) - Method in class io.github.robwin.circularbuffer.ConcurrentEvictingQueue
Returns an array containing all of the elements in this queue, in proper sequence; the runtime type of the returned array is that of the specified array.
toList() - Method in interface io.github.robwin.circularbuffer.CircularFifoBuffer
Returns a list containing all of the elements in this CircularFifoBuffer.
toList() - Method in class io.github.robwin.circularbuffer.ConcurrentCircularFifoBuffer
Returns a list containing all of the elements in this CircularFifoBuffer.
toString() - Method in class io.github.robwin.cache.event.CacheOnErrorEvent
 
toString() - Method in class io.github.robwin.cache.event.CacheOnHitEvent
 
toString() - Method in class io.github.robwin.cache.event.CacheOnMissEvent
 
toString() - Method in enum io.github.robwin.circuitbreaker.CircuitBreaker.StateTransition
 
toString() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnCallNotPermittedEvent
 
toString() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnErrorEvent
 
toString() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnIgnoredErrorEvent
 
toString() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnStateTransitionEvent
 
toString() - Method in class io.github.robwin.circuitbreaker.event.CircuitBreakerOnSuccessEvent
 
toString() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
toString() - Method in class io.github.robwin.metrics.StopWatch
 
toString() - Method in class io.github.robwin.ratelimiter.event.AbstractRateLimiterEvent
 
toString() - Method in class io.github.robwin.retry.event.RetryOnErrorEvent
 
toString() - Method in class io.github.robwin.retry.event.RetryOnSuccessEvent
 
transitionToClosedState(CircuitBreaker.State) - Static method in enum io.github.robwin.circuitbreaker.CircuitBreaker.StateTransition
 
transitionToClosedState() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Transitions the state machine to CLOSED state.
transitionToClosedState() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
 
transitionToHalfOpenState(CircuitBreaker.State) - Static method in enum io.github.robwin.circuitbreaker.CircuitBreaker.StateTransition
 
transitionToHalfOpenState() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Transitions the state machine to HALF_OPEN state.
transitionToHalfOpenState() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
 
transitionToOpenState(CircuitBreaker.State) - Static method in enum io.github.robwin.circuitbreaker.CircuitBreaker.StateTransition
 
transitionToOpenState() - Method in interface io.github.robwin.circuitbreaker.CircuitBreaker
Transitions the state machine to OPEN state.
transitionToOpenState() - Method in class io.github.robwin.circuitbreaker.internal.CircuitBreakerStateMachine
 

V

valueOf(String) - Static method in enum io.github.robwin.cache.event.CacheEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.robwin.circuitbreaker.CircuitBreaker.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.robwin.circuitbreaker.CircuitBreaker.StateTransition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.robwin.circuitbreaker.event.CircuitBreakerEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.robwin.ratelimiter.event.RateLimiterEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.robwin.retry.event.RetryEvent.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.github.robwin.cache.event.CacheEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.robwin.circuitbreaker.CircuitBreaker.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.robwin.circuitbreaker.CircuitBreaker.StateTransition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.robwin.circuitbreaker.event.CircuitBreakerEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.robwin.ratelimiter.event.RateLimiterEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.robwin.retry.event.RetryEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitDuration(Duration) - Method in class io.github.robwin.retry.RetryConfig.Builder
 
waitDurationInOpenState(Duration) - Method in class io.github.robwin.circuitbreaker.CircuitBreakerConfig.Builder
Configures the wait duration which specifies how long the CircuitBreaker should stay open, before it switches to half open.
waitForPermission(RateLimiter) - Static method in interface io.github.robwin.ratelimiter.RateLimiter
Will wait for permission within default timeout duration.
withCache(Cache<K, T>) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedSupplier
 
withCache(Cache<K, T>) - Method in class io.github.robwin.decorators.Decorators.DecorateSupplier
 
withCircuitBreaker(CircuitBreaker) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedFunction
 
withCircuitBreaker(CircuitBreaker) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedRunnable
 
withCircuitBreaker(CircuitBreaker) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedSupplier
 
withCircuitBreaker(CircuitBreaker) - Method in class io.github.robwin.decorators.Decorators.DecorateFunction
 
withCircuitBreaker(CircuitBreaker) - Method in class io.github.robwin.decorators.Decorators.DecorateRunnable
 
withCircuitBreaker(CircuitBreaker) - Method in class io.github.robwin.decorators.Decorators.DecorateSupplier
 
withRateLimiter(RateLimiter) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedFunction
 
withRateLimiter(RateLimiter) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedRunnable
 
withRateLimiter(RateLimiter) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedSupplier
 
withRateLimiter(RateLimiter) - Method in class io.github.robwin.decorators.Decorators.DecorateFunction
 
withRateLimiter(RateLimiter) - Method in class io.github.robwin.decorators.Decorators.DecorateRunnable
 
withRateLimiter(RateLimiter) - Method in class io.github.robwin.decorators.Decorators.DecorateSupplier
 
withRetry(Retry) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedFunction
 
withRetry(Retry) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedRunnable
 
withRetry(Retry) - Method in class io.github.robwin.decorators.Decorators.DecorateCheckedSupplier
 
withRetry(Retry) - Method in class io.github.robwin.decorators.Decorators.DecorateFunction
 
withRetry(Retry) - Method in class io.github.robwin.decorators.Decorators.DecorateRunnable
 
withRetry(Retry) - Method in class io.github.robwin.decorators.Decorators.DecorateSupplier
 
A B C D F G I L M O P R S T V W 
Skip navigation links