Skip navigation links
A B C D E F G H I L M N O P R S T U V W Z 

A

AbstractBackend<K> - Class in io.github.bucket4j.distributed.proxy
 
AbstractBackend(ClientSideConfig) - Constructor for class io.github.bucket4j.distributed.proxy.AbstractBackend
 
AbstractBinaryTransaction - Class in io.github.bucket4j.distributed.remote
 
AbstractBinaryTransaction(byte[]) - Constructor for class io.github.bucket4j.distributed.remote.AbstractBinaryTransaction
 
AbstractBucket - Class in io.github.bucket4j
 
AbstractBucket(BucketListener) - Constructor for class io.github.bucket4j.AbstractBucket
 
AbstractCompareAndSwapBasedBackend<K> - Class in io.github.bucket4j.distributed.proxy.generic.compare_and_swap
 
AbstractCompareAndSwapBasedBackend(ClientSideConfig) - Constructor for class io.github.bucket4j.distributed.proxy.generic.compare_and_swap.AbstractCompareAndSwapBasedBackend
 
AbstractLockBasedBackend<K> - Class in io.github.bucket4j.distributed.proxy.generic.select_for_update
 
AbstractLockBasedBackend(ClientSideConfig) - Constructor for class io.github.bucket4j.distributed.proxy.generic.select_for_update.AbstractLockBasedBackend
 
addConsumedTokens(long) - Method in class io.github.bucket4j.distributed.remote.RemoteStat
 
addLimit(Bandwidth) - Method in class io.github.bucket4j.ConfigurationBuilder
Adds limited bandwidth for all buckets which will be constructed by this builder instance.
addLimit(Bandwidth) - Method in class io.github.bucket4j.local.LocalBucketBuilder
Adds limited bandwidth for all buckets which will be constructed by this builder.
addTokens(long) - Method in class io.github.bucket4j.AbstractBucket
 
addTokens(long) - Method in interface io.github.bucket4j.Bucket
Add tokensToAdd to bucket.
addTokens(Bandwidth[], long) - Method in interface io.github.bucket4j.BucketState
 
addTokens(Bandwidth[], long) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
addTokens(Bandwidth[], long) - Method in class io.github.bucket4j.BucketStateIEEE754
 
addTokens(long) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Asynchronous version of Bucket.addTokens(long), follows the same semantic.
addTokens(long) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
addTokens(long) - Method in interface io.github.bucket4j.distributed.AsyncVerboseBucket
Does the same that Bucket.addTokens(long)
addTokens(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
addTokens(long) - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
addTokens(long) - Method in interface io.github.bucket4j.VerboseBucket
Does the same that Bucket.addTokens(long)
AddTokensCommand - Class in io.github.bucket4j.distributed.remote.commands
 
AddTokensCommand(long) - Constructor for class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
addTokensImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
addTokensImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
addTokensImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
addTokensImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
addTokensVerboseImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
addTokensVerboseImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
addTokensVerboseImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
addTokensVerboseImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
ALL - Static variable in enum io.github.bucket4j.MathType
 
allocateTransaction(K) - Method in class io.github.bucket4j.distributed.proxy.generic.compare_and_swap.AbstractCompareAndSwapBasedBackend
 
allocateTransaction(K) - Method in class io.github.bucket4j.distributed.proxy.generic.select_for_update.AbstractLockBasedBackend
 
apply(CommandExecutor) - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.BatchingOptimization
 
apply(AsyncCommandExecutor) - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.BatchingOptimization
 
apply(CommandExecutor) - Method in class io.github.bucket4j.distributed.proxy.optimization.delay.DelayOptimization
 
apply(AsyncCommandExecutor) - Method in class io.github.bucket4j.distributed.proxy.optimization.delay.DelayOptimization
 
apply(CommandExecutor) - Method in interface io.github.bucket4j.distributed.proxy.optimization.Optimization
 
apply(AsyncCommandExecutor) - Method in interface io.github.bucket4j.distributed.proxy.optimization.Optimization
 
apply(CommandExecutor) - Method in class io.github.bucket4j.distributed.proxy.optimization.predictive.PredictiveOptimization
 
apply(AsyncCommandExecutor) - Method in class io.github.bucket4j.distributed.proxy.optimization.predictive.PredictiveOptimization
 
asAsync() - Method in class io.github.bucket4j.distributed.proxy.AbstractBackend
 
asAsync() - Method in interface io.github.bucket4j.distributed.proxy.Backend
TODO
asBlocking() - Method in class io.github.bucket4j.AbstractBucket
 
asBlocking() - Method in interface io.github.bucket4j.Bucket
Returns the BlockingBucket view of this bucket, that provides operations which are able to block caller thread.
asException() - Method in class io.github.bucket4j.distributed.remote.BucketNotFoundError
 
asException() - Method in interface io.github.bucket4j.distributed.remote.CommandError
 
asException() - Method in class io.github.bucket4j.distributed.remote.UnsupportedTypeError
 
asException() - Method in class io.github.bucket4j.distributed.remote.UsageOfObsoleteApiError
 
asException() - Method in class io.github.bucket4j.distributed.remote.UsageOfUnsupportedApiError
 
asLocal() - Method in class io.github.bucket4j.distributed.remote.RemoteVerboseResult
 
asScheduler() - Method in class io.github.bucket4j.AbstractBucket
 
asScheduler() - Method in interface io.github.bucket4j.Bucket
TODO
asScheduler() - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Returns asynchronous view of this bucket that allows to use bucket as async scheduler.
asScheduler() - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
asScheduler() - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
asVerbose() - Method in class io.github.bucket4j.AbstractBucket
 
asVerbose() - Method in interface io.github.bucket4j.Bucket
Returns the verbose view of this bucket.
asVerbose() - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Returns the verbose view of this bucket.
asVerbose() - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
asVerbose() - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
asVerbose() - Method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
AsyncBackend<K> - Interface in io.github.bucket4j.distributed.proxy
 
AsyncBatchingExecutor - Class in io.github.bucket4j.distributed.proxy.optimization.batch
 
AsyncBatchingExecutor(AsyncCommandExecutor, OptimizationListener) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.batch.AsyncBatchingExecutor
 
AsyncBucketProxy - Interface in io.github.bucket4j.distributed
Provides asynchronous API for bucket.
AsyncBucketProxyAdapter - Class in io.github.bucket4j.distributed
 
AsyncBucketProxyAdapter(Bucket) - Constructor for class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
AsyncCommandExecutor - Interface in io.github.bucket4j.distributed.proxy
TODO javadocs
asyncModeIsNotSupported() - Static method in class io.github.bucket4j.BucketExceptions
 
AsyncVerboseBucket - Interface in io.github.bucket4j.distributed
Intent of this interface is to provide the verbose version of AsyncBucketProxy API.

B

Backend<K> - Interface in io.github.bucket4j.distributed.proxy
TODO javadocs Represents an extension point of bucket4j library.
BackwardCompatibilityException - Exception in io.github.bucket4j.distributed.versioning
 
BackwardCompatibilityException(String) - Constructor for exception io.github.bucket4j.distributed.versioning.BackwardCompatibilityException
 
backwardCompatibleWith(Version) - Static method in class io.github.bucket4j.distributed.proxy.ClientSideConfig
TODO
Bandwidth - Class in io.github.bucket4j
Anatomy of bandwidth:
BatchFailedException - Exception in io.github.bucket4j.distributed.proxy.optimization.batch
 
BatchFailedException(Throwable) - Constructor for exception io.github.bucket4j.distributed.proxy.optimization.batch.BatchFailedException
 
batching() - Static method in class io.github.bucket4j.distributed.proxy.optimization.Optimizations
 
BatchingExecutor - Class in io.github.bucket4j.distributed.proxy.optimization.batch
 
BatchingExecutor(CommandExecutor, OptimizationListener) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.batch.BatchingExecutor
 
BatchingOptimization - Class in io.github.bucket4j.distributed.proxy.optimization.batch
 
BatchingOptimization(OptimizationListener) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.batch.BatchingOptimization
 
begin() - Method in interface io.github.bucket4j.distributed.proxy.generic.select_for_update.LockBasedTransaction
Begins transaction if underlying storage requires transactions.
BlockingBucket - Interface in io.github.bucket4j
Provides blocking API for bucket that allows to use bucket as scheduler.
BlockingStrategy - Interface in io.github.bucket4j
Specifies the way to block current thread to amount of time required to refill missed number of tokens in the bucket.
BOOLEAN_HANDLE - Static variable in class io.github.bucket4j.distributed.serialization.PrimitiveSerializationHandles
 
Bucket - Interface in io.github.bucket4j
Performs rate limiting using algorithm based on top of ideas of Token Bucket.
Bucket4j - Class in io.github.bucket4j
Deprecated. 
BucketConfiguration - Class in io.github.bucket4j
 
BucketConfiguration(List<Bandwidth>) - Constructor for class io.github.bucket4j.BucketConfiguration
 
BucketEntryWrapper - Class in io.github.bucket4j.distributed.remote.commands
 
BucketEntryWrapper(RemoteBucketState) - Constructor for class io.github.bucket4j.distributed.remote.commands.BucketEntryWrapper
 
BucketExceptions - Class in io.github.bucket4j
 
BucketListener - Interface in io.github.bucket4j
Interface for listening bucket related events.
bucketNotFound() - Static method in class io.github.bucket4j.distributed.remote.CommandResult
 
BucketNotFoundError - Class in io.github.bucket4j.distributed.remote
 
BucketNotFoundError() - Constructor for class io.github.bucket4j.distributed.remote.BucketNotFoundError
 
BucketNotFoundException - Exception in io.github.bucket4j.distributed.proxy
Exception which thrown each time when DefaultBucketProxy found that bucket state has been lost, and DefaultBucketProxy is unable to repair bucket state or recovery strategy is RecoveryStrategy.THROW_BUCKET_NOT_FOUND_EXCEPTION.
BucketNotFoundException() - Constructor for exception io.github.bucket4j.distributed.proxy.BucketNotFoundException
 
BucketProxy - Interface in io.github.bucket4j.distributed
 
BucketState - Interface in io.github.bucket4j
 
BucketState64BitsInteger - Class in io.github.bucket4j
 
BucketState64BitsInteger(BucketConfiguration, long) - Constructor for class io.github.bucket4j.BucketState64BitsInteger
 
BucketStateIEEE754 - Class in io.github.bucket4j
 
BucketStateIEEE754(BucketConfiguration, long) - Constructor for class io.github.bucket4j.BucketStateIEEE754
 
build() - Method in class io.github.bucket4j.ConfigurationBuilder
 
build() - Method in class io.github.bucket4j.local.LocalBucketBuilder
Constructs the bucket.
buildConfiguration() - Method in class io.github.bucket4j.ConfigurationBuilder
Deprecated.
builder() - Static method in interface io.github.bucket4j.Bucket
Creates the new builder of in-memory buckets.
builder() - Static method in class io.github.bucket4j.Bucket4j
Deprecated. 
builder() - Static method in class io.github.bucket4j.BucketConfiguration
 
builder() - Method in class io.github.bucket4j.distributed.proxy.AbstractBackend
 
builder() - Method in interface io.github.bucket4j.distributed.proxy.AsyncBackend
 
builder() - Method in interface io.github.bucket4j.distributed.proxy.Backend
TODO fix javadocs Constructs an instance of DefaultBucketProxy which state actually stored inside in-memory data-jvm, the bucket stored in the jvm immediately, so one network request will be issued to jvm.
buildProxy(K, BucketConfiguration) - Method in interface io.github.bucket4j.distributed.proxy.RemoteAsyncBucketBuilder
TODO
buildProxy(K, Supplier<CompletableFuture<BucketConfiguration>>) - Method in interface io.github.bucket4j.distributed.proxy.RemoteAsyncBucketBuilder
TODO
buildProxy(K, BucketConfiguration) - Method in interface io.github.bucket4j.distributed.proxy.RemoteBucketBuilder
TODO
buildProxy(K, Supplier<BucketConfiguration>) - Method in interface io.github.bucket4j.distributed.proxy.RemoteBucketBuilder
TODO
byNumber(int) - Static method in enum io.github.bucket4j.distributed.versioning.Versions
 

C

calculateDelayNanosAfterWillBePossibleToConsume(Bandwidth[], long, long) - Method in interface io.github.bucket4j.BucketState
 
calculateDelayNanosAfterWillBePossibleToConsume(Bandwidth[], long, long) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
calculateDelayNanosAfterWillBePossibleToConsume(Bandwidth[], long, long) - Method in class io.github.bucket4j.BucketStateIEEE754
 
calculateDelayNanosAfterWillBePossibleToConsume(long, long) - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
calculateFullRefillingTime(Bandwidth[], long) - Method in interface io.github.bucket4j.BucketState
 
calculateFullRefillingTime(Bandwidth[], long) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
calculateFullRefillingTime(Bandwidth[], long) - Method in class io.github.bucket4j.BucketStateIEEE754
 
calculateFullRefillingTime(long) - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
canBeConsumed(long) - Static method in class io.github.bucket4j.EstimationProbe
 
canBeConsumed() - Method in class io.github.bucket4j.EstimationProbe
Flag describes result of consumption operation.
canNotBeConsumed(long, long) - Static method in class io.github.bucket4j.EstimationProbe
 
check(int, Versions, Versions) - Static method in enum io.github.bucket4j.distributed.versioning.Versions
 
checkConfiguration(BucketConfiguration) - Static method in class io.github.bucket4j.LimitChecker
 
checkMax(int, Versions) - Static method in enum io.github.bucket4j.distributed.versioning.Versions
 
checkMaxWaitTime(long) - Static method in class io.github.bucket4j.LimitChecker
 
checkMin(int, Versions) - Static method in enum io.github.bucket4j.distributed.versioning.Versions
 
checkScheduler(ScheduledExecutorService) - Static method in class io.github.bucket4j.LimitChecker
 
checkTokensToAdd(long) - Static method in class io.github.bucket4j.LimitChecker
 
checkTokensToConsume(long) - Static method in class io.github.bucket4j.LimitChecker
 
classic(long, Refill) - Static method in class io.github.bucket4j.Bandwidth
Specifies limitation in classic interpretation of token-bucket algorithm.
clear() - Method in class io.github.bucket4j.distributed.proxy.optimization.predictive.Sampling
 
ClientSideConfig - Class in io.github.bucket4j.distributed.proxy
TODO
ClientSideConfig(Version, Optional<TimeMeter>) - Constructor for class io.github.bucket4j.distributed.proxy.ClientSideConfig
 
command - Variable in class io.github.bucket4j.distributed.proxy.optimization.batch.WaitingTask
 
CommandError - Interface in io.github.bucket4j.distributed.remote
 
CommandExecutor - Interface in io.github.bucket4j.distributed.proxy
 
CommandResult<T> - Class in io.github.bucket4j.distributed.remote
 
CommandResult(T, int) - Constructor for class io.github.bucket4j.distributed.remote.CommandResult
 
commit() - Method in interface io.github.bucket4j.distributed.proxy.generic.select_for_update.LockBasedTransaction
Commits transaction if underlying storage requires transactions
ComparableByContent<T extends ComparableByContent> - Interface in io.github.bucket4j.util
 
compareAndSwap(byte[], byte[]) - Method in interface io.github.bucket4j.distributed.proxy.generic.compare_and_swap.CompareAndSwapBasedTransaction
Compares and swap data associated with key
CompareAndSwapBasedTransaction - Interface in io.github.bucket4j.distributed.proxy.generic.compare_and_swap
 
completedFuture(Supplier<T>) - Static method in class io.github.bucket4j.AbstractBucket
 
configurationBuilder() - Static method in class io.github.bucket4j.Bucket4j
Deprecated. 
ConfigurationBuilder - Class in io.github.bucket4j
TODO add notes for building configuration
ConfigurationBuilder() - Constructor for class io.github.bucket4j.ConfigurationBuilder
 
consume(long, BlockingStrategy) - Method in class io.github.bucket4j.AbstractBucket
 
consume(long, ScheduledExecutorService) - Method in class io.github.bucket4j.AbstractBucket
 
consume(long, BlockingStrategy) - Method in interface io.github.bucket4j.BlockingBucket
Consumes a specified number of tokens from the bucket.
consume(long) - Method in interface io.github.bucket4j.BlockingBucket
This is just overloaded equivalent of BlockingBucket.consume(long, BlockingStrategy)
consume(Bandwidth[], long) - Method in interface io.github.bucket4j.BucketState
 
consume(Bandwidth[], long) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
consume(Bandwidth[], long) - Method in class io.github.bucket4j.BucketStateIEEE754
 
consume(long, ScheduledExecutorService) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
consume(long) - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
consume(long, ScheduledExecutorService) - Method in interface io.github.bucket4j.ScheduledBucket
Consumes the specified number of tokens from the bucket.
ConsumeAsMuchAsPossibleCommand - Class in io.github.bucket4j.distributed.remote.commands
 
ConsumeAsMuchAsPossibleCommand(long) - Constructor for class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
consumeAsMuchAsPossibleImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
consumeAsMuchAsPossibleImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
consumeAsMuchAsPossibleImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
consumeAsMuchAsPossibleImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
consumeAsMuchAsPossibleVerboseImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
consumeAsMuchAsPossibleVerboseImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
consumeAsMuchAsPossibleVerboseImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
consumeAsMuchAsPossibleVerboseImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
consumed(long, long) - Static method in class io.github.bucket4j.ConsumptionProbe
 
consumeIgnoringRateLimits(long) - Method in class io.github.bucket4j.AbstractBucket
 
consumeIgnoringRateLimits(long) - Method in interface io.github.bucket4j.Bucket
Consumes tokens from bucket ignoring all limits.
consumeIgnoringRateLimits(long) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Asynchronous version of Bucket.consumeIgnoringRateLimits(long), follows the same semantic.
consumeIgnoringRateLimits(long) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
consumeIgnoringRateLimits(long) - Method in interface io.github.bucket4j.distributed.AsyncVerboseBucket
consumeIgnoringRateLimits(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
consumeIgnoringRateLimits(long) - Method in interface io.github.bucket4j.VerboseBucket
ConsumeIgnoringRateLimitsCommand - Class in io.github.bucket4j.distributed.remote.commands
 
ConsumeIgnoringRateLimitsCommand(long) - Constructor for class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
consumeIgnoringRateLimitsImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
consumeIgnoringRateLimitsImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
consumeIgnoringRateLimitsImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
consumeIgnoringRateLimitsImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
consumeIgnoringRateLimitsVerboseImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
consumeIgnoringRateLimitsVerboseImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
consumeIgnoringRateLimitsVerboseImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
consumeIgnoringRateLimitsVerboseImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
consumeUninterruptibly(long, UninterruptibleBlockingStrategy) - Method in class io.github.bucket4j.AbstractBucket
 
consumeUninterruptibly(long, UninterruptibleBlockingStrategy) - Method in interface io.github.bucket4j.BlockingBucket
Has same semantic with BlockingBucket.consume(long, BlockingStrategy) but ignores interrupts(just restores interruption flag on exit).
consumeUninterruptibly(long) - Method in interface io.github.bucket4j.BlockingBucket
ConsumptionProbe - Class in io.github.bucket4j
Describes tokens consumed, tokens remaining, time required for token regeneration to occur, and the current bucket configuration after consumption.
copy() - Method in interface io.github.bucket4j.BucketState
 
copy() - Method in class io.github.bucket4j.BucketState64BitsInteger
 
copy() - Method in class io.github.bucket4j.BucketStateIEEE754
 
copy() - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
copy() - Method in class io.github.bucket4j.distributed.remote.RemoteStat
 
copyBucketState() - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
copyStateFrom(BucketState) - Method in interface io.github.bucket4j.BucketState
 
copyStateFrom(BucketState) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
copyStateFrom(BucketState) - Method in class io.github.bucket4j.BucketStateIEEE754
 
CORE_HANDLES - Static variable in interface io.github.bucket4j.distributed.serialization.SerializationHandle
 
create(byte[]) - Method in interface io.github.bucket4j.distributed.proxy.generic.select_for_update.LockBasedTransaction
Creates the data by the key associated with this transaction.
createDefault() - Static method in interface io.github.bucket4j.distributed.proxy.optimization.OptimizationListener
 
createDefault(DelayParameters) - Static method in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
createInitialState(BucketConfiguration, MathType, long) - Static method in interface io.github.bucket4j.BucketState
 
CreateInitialStateAndExecuteCommand<T> - Class in io.github.bucket4j.distributed.remote.commands
 
CreateInitialStateAndExecuteCommand(BucketConfiguration, RemoteCommand<T>) - Constructor for class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
CreateInitialStateCommand - Class in io.github.bucket4j.distributed.remote.commands
 
CreateInitialStateCommand(BucketConfiguration) - Constructor for class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
createSnapshot() - Method in interface io.github.bucket4j.Bucket
Creates the copy of internal state.
createSnapshot() - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
createSnapshot() - Method in class io.github.bucket4j.local.LockFreeBucket
 
createSnapshot() - Method in class io.github.bucket4j.local.SynchronizedBucket
 
CreateSnapshotCommand - Class in io.github.bucket4j.distributed.remote.commands
 
CreateSnapshotCommand() - Constructor for class io.github.bucket4j.distributed.remote.commands.CreateSnapshotCommand
 
currentTimeNanos() - Method in interface io.github.bucket4j.TimeMeter
Returns current time in nanosecond precision, but not necessarily nanosecond resolution.

D

DataOutputSerializationAdapter - Class in io.github.bucket4j.distributed.serialization
 
DEFAULT_MAX_SAMPLES - Static variable in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
DEFAULT_MIN_SAMPLES - Static variable in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
DefaultAsyncBucketProxy - Class in io.github.bucket4j.distributed.proxy
 
DefaultAsyncBucketProxy(AsyncCommandExecutor, RecoveryStrategy, Supplier<CompletableFuture<BucketConfiguration>>) - Constructor for class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
DefaultBucketProxy - Class in io.github.bucket4j.distributed.proxy
 
DefaultBucketProxy(Supplier<BucketConfiguration>, CommandExecutor, RecoveryStrategy) - Constructor for class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
DefaultOptimizationListener - Class in io.github.bucket4j.distributed.proxy.optimization
 
DefaultOptimizationListener() - Constructor for class io.github.bucket4j.distributed.proxy.optimization.DefaultOptimizationListener
 
delaying(DelayParameters) - Static method in class io.github.bucket4j.distributed.proxy.optimization.Optimizations
 
DelayOptimization - Class in io.github.bucket4j.distributed.proxy.optimization.delay
 
DelayOptimization(DelayParameters, OptimizationListener, TimeMeter) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.delay.DelayOptimization
 
DelayParameters - Class in io.github.bucket4j.distributed.proxy.optimization
 
DelayParameters(long, Duration) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.DelayParameters
 
DeserializationAdapter<S> - Interface in io.github.bucket4j.distributed.serialization
 
deserialize(DeserializationAdapter<S>, S, Version) - Static method in interface io.github.bucket4j.BucketState
 
deserialize(DeserializationAdapter<I>, I, Version) - Static method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
deserialize(DeserializationAdapter<I>, I, Version) - Method in interface io.github.bucket4j.distributed.serialization.SerializationHandle
 
deserializeRequest(byte[]) - Static method in class io.github.bucket4j.distributed.serialization.InternalSerializationHelper
 
deserializeResult(byte[], Version) - Static method in class io.github.bucket4j.distributed.serialization.InternalSerializationHelper
 
deserializeState(byte[]) - Static method in class io.github.bucket4j.distributed.serialization.InternalSerializationHelper
 

E

empty() - Static method in class io.github.bucket4j.distributed.remote.CommandResult
 
equals(Object) - Method in class io.github.bucket4j.Bandwidth
 
equals(Object) - Method in class io.github.bucket4j.BucketConfiguration
 
equals(T, T) - Static method in interface io.github.bucket4j.util.ComparableByContent
 
equalsByContent(Bandwidth) - Method in class io.github.bucket4j.Bandwidth
 
equalsByContent(BucketConfiguration) - Method in class io.github.bucket4j.BucketConfiguration
 
equalsByContent(BucketState64BitsInteger) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
equalsByContent(BucketStateIEEE754) - Method in class io.github.bucket4j.BucketStateIEEE754
 
equalsByContent(ConsumptionProbe) - Method in class io.github.bucket4j.ConsumptionProbe
 
equalsByContent(BucketNotFoundError) - Method in class io.github.bucket4j.distributed.remote.BucketNotFoundError
 
equalsByContent(CommandResult) - Method in class io.github.bucket4j.distributed.remote.CommandResult
 
equalsByContent(AddTokensCommand) - Method in class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
equalsByContent(ConsumeAsMuchAsPossibleCommand) - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
equalsByContent(ConsumeIgnoringRateLimitsCommand) - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
equalsByContent(CreateInitialStateAndExecuteCommand) - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
equalsByContent(CreateInitialStateCommand) - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
equalsByContent(CreateSnapshotCommand) - Method in class io.github.bucket4j.distributed.remote.commands.CreateSnapshotCommand
 
equalsByContent(EstimateAbilityToConsumeCommand) - Method in class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
equalsByContent(GetAvailableTokensCommand) - Method in class io.github.bucket4j.distributed.remote.commands.GetAvailableTokensCommand
 
equalsByContent(GetConfigurationCommand) - Method in class io.github.bucket4j.distributed.remote.commands.GetConfigurationCommand
 
equalsByContent(MultiCommand) - Method in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
equalsByContent(ReplaceConfigurationOrReturnPreviousCommand) - Method in class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
equalsByContent(ReserveAndCalculateTimeToSleepCommand) - Method in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
equalsByContent(SyncCommand) - Method in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
equalsByContent(TryConsumeAndReturnRemainingTokensCommand) - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
equalsByContent(TryConsumeCommand) - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
equalsByContent(VerboseCommand<?>) - Method in class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
equalsByContent(MultiResult) - Method in class io.github.bucket4j.distributed.remote.MultiResult
 
equalsByContent(RemoteBucketState) - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
equalsByContent(RemoteStat) - Method in class io.github.bucket4j.distributed.remote.RemoteStat
 
equalsByContent(RemoteVerboseResult<?>) - Method in class io.github.bucket4j.distributed.remote.RemoteVerboseResult
 
equalsByContent(UnsupportedTypeError) - Method in class io.github.bucket4j.distributed.remote.UnsupportedTypeError
 
equalsByContent(UsageOfObsoleteApiError) - Method in class io.github.bucket4j.distributed.remote.UsageOfObsoleteApiError
 
equalsByContent(UsageOfUnsupportedApiError) - Method in class io.github.bucket4j.distributed.remote.UsageOfUnsupportedApiError
 
equalsByContent(EstimationProbe) - Method in class io.github.bucket4j.EstimationProbe
 
equalsByContent(T) - Method in interface io.github.bucket4j.util.ComparableByContent
 
equalsByContent(VerboseResult<?>) - Method in class io.github.bucket4j.VerboseResult
 
estimateAbilityToConsume(long) - Method in class io.github.bucket4j.AbstractBucket
 
estimateAbilityToConsume(long) - Method in interface io.github.bucket4j.Bucket
Estimates ability to consume a specified number of tokens.
estimateAbilityToConsume(long) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Asynchronous version of Bucket.estimateAbilityToConsume(long), follows the same semantic.
estimateAbilityToConsume(long) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
estimateAbilityToConsume(long) - Method in interface io.github.bucket4j.distributed.AsyncVerboseBucket
estimateAbilityToConsume(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
estimateAbilityToConsume(long) - Method in interface io.github.bucket4j.VerboseBucket
EstimateAbilityToConsumeCommand - Class in io.github.bucket4j.distributed.remote.commands
 
EstimateAbilityToConsumeCommand(long) - Constructor for class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
estimateAbilityToConsumeImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
estimateAbilityToConsumeImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
estimateAbilityToConsumeImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
estimateAbilityToConsumeImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
estimateAbilityToConsumeVerboseImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
estimateAbilityToConsumeVerboseImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
estimateAbilityToConsumeVerboseImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
estimateAbilityToConsumeVerboseImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.CreateSnapshotCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.GetAvailableTokensCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.GetConfigurationCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
estimateTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
estimateTokensToConsume() - Method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
EstimationProbe - Class in io.github.bucket4j
Describes the estimation result.
execute(K, Request<T>) - Method in class io.github.bucket4j.distributed.proxy.AbstractBackend
 
execute(RemoteCommand<T>) - Method in interface io.github.bucket4j.distributed.proxy.CommandExecutor
 
execute(K, Request<T>) - Method in class io.github.bucket4j.distributed.proxy.generic.compare_and_swap.AbstractCompareAndSwapBasedBackend
 
execute(K, Request<T>) - Method in class io.github.bucket4j.distributed.proxy.generic.select_for_update.AbstractLockBasedBackend
 
execute(RemoteCommand<T>) - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.BatchingExecutor
 
execute() - Method in class io.github.bucket4j.distributed.remote.AbstractBinaryTransaction
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.CreateSnapshotCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.GetAvailableTokensCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.GetConfigurationCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
execute(MutableBucketEntry, long) - Method in class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
execute(MutableBucketEntry, long) - Method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
executeAsync(K, Request<T>) - Method in class io.github.bucket4j.distributed.proxy.AbstractBackend
 
executeAsync(RemoteCommand<T>) - Method in interface io.github.bucket4j.distributed.proxy.AsyncCommandExecutor
TODO javadocs
executeAsync(K, Request<T>) - Method in class io.github.bucket4j.distributed.proxy.generic.compare_and_swap.AbstractCompareAndSwapBasedBackend
 
executeAsync(K, Request<T>) - Method in class io.github.bucket4j.distributed.proxy.generic.select_for_update.AbstractLockBasedBackend
 
executeAsync(RemoteCommand<T>) - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.AsyncBatchingExecutor
 
exists() - Method in class io.github.bucket4j.distributed.proxy.generic.GenericEntry
 
exists() - Method in class io.github.bucket4j.distributed.remote.commands.BucketEntryWrapper
 
exists() - Method in interface io.github.bucket4j.distributed.remote.MutableBucketEntry
 

F

failedFuture(Throwable) - Static method in class io.github.bucket4j.AbstractBucket
 
FakeLock - Class in io.github.bucket4j.local
This is lock implementation which actually lock nothing, is used for SynchronizationStrategy.NONE
FALSE - Static variable in class io.github.bucket4j.distributed.remote.CommandResult
 
fromSync(Bucket) - Static method in interface io.github.bucket4j.distributed.AsyncBucketProxy
 
future - Variable in class io.github.bucket4j.distributed.proxy.optimization.batch.WaitingTask
 

G

GenericEntry - Class in io.github.bucket4j.distributed.proxy.generic
 
GenericEntry(byte[], Version) - Constructor for class io.github.bucket4j.distributed.proxy.generic.GenericEntry
 
get() - Method in interface io.github.bucket4j.distributed.proxy.generic.compare_and_swap.CompareAndSwapBasedTransaction
Reads data if it exists
get() - Method in class io.github.bucket4j.distributed.proxy.generic.GenericEntry
 
get() - Method in class io.github.bucket4j.distributed.remote.AbstractBinaryTransaction
 
get() - Method in class io.github.bucket4j.distributed.remote.commands.BucketEntryWrapper
 
get() - Method in interface io.github.bucket4j.distributed.remote.MutableBucketEntry
 
getAllHandles() - Method in class io.github.bucket4j.distributed.serialization.SerializationHandles
 
getAvailableTokens() - Method in interface io.github.bucket4j.Bucket
Returns amount of available tokens in this bucket.
getAvailableTokens(Bandwidth[]) - Method in interface io.github.bucket4j.BucketState
 
getAvailableTokens(Bandwidth[]) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
getAvailableTokens(Bandwidth[]) - Method in class io.github.bucket4j.BucketStateIEEE754
 
getAvailableTokens() - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Returns amount of available tokens in this bucket.
getAvailableTokens() - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
getAvailableTokens() - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
getAvailableTokens() - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
getAvailableTokens() - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
getAvailableTokens() - Method in class io.github.bucket4j.local.LockFreeBucket
 
getAvailableTokens() - Method in class io.github.bucket4j.local.SynchronizedBucket
 
getAvailableTokens() - Method in interface io.github.bucket4j.VerboseBucket
Does the same that Bucket.getAvailableTokens()
GetAvailableTokensCommand - Class in io.github.bucket4j.distributed.remote.commands
 
GetAvailableTokensCommand() - Constructor for class io.github.bucket4j.distributed.remote.commands.GetAvailableTokensCommand
 
getAvailableTokensVerboseImpl() - Method in class io.github.bucket4j.AbstractBucket
 
getAvailableTokensVerboseImpl() - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
getAvailableTokensVerboseImpl() - Method in class io.github.bucket4j.local.LockFreeBucket
 
getAvailableTokensVerboseImpl() - Method in class io.github.bucket4j.local.SynchronizedBucket
 
getBackwardCompatibilityVersion() - Method in class io.github.bucket4j.distributed.proxy.AbstractBackend
 
getBackwardCompatibilityVersion() - Method in class io.github.bucket4j.distributed.proxy.ClientSideConfig
TODO
getBackwardCompatibilityVersion() - Method in class io.github.bucket4j.distributed.remote.Request
 
getBandwidths() - Method in class io.github.bucket4j.BucketConfiguration
 
getCapacity() - Method in class io.github.bucket4j.Bandwidth
 
getClientSideClock() - Method in class io.github.bucket4j.distributed.proxy.ClientSideConfig
TODO
getClientSideConfig() - Method in class io.github.bucket4j.distributed.proxy.AbstractBackend
 
getClientSideTime() - Method in class io.github.bucket4j.distributed.proxy.AbstractBackend
 
getClientSideTime() - Method in class io.github.bucket4j.distributed.remote.Request
 
getCommand() - Method in class io.github.bucket4j.distributed.remote.Request
 
getCommands() - Method in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
getConfiguration() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
getConfiguration() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
getConfiguration() - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
getConfiguration() - Method in interface io.github.bucket4j.local.LocalBucket
Returns configuration of this bucket.
getConfiguration() - Method in class io.github.bucket4j.local.LockFreeBucket
 
getConfiguration() - Method in class io.github.bucket4j.local.SynchronizedBucket
 
getConfiguration() - Method in class io.github.bucket4j.VerboseResult
 
GetConfigurationCommand - Class in io.github.bucket4j.distributed.remote.commands
 
GetConfigurationCommand() - Constructor for class io.github.bucket4j.distributed.remote.commands.GetConfigurationCommand
 
getConsumed() - Method in class io.github.bucket4j.SimpleBucketListener
 
getConsumedTokens(Nothing) - Method in class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
getConsumedTokens(Long) - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
getConsumedTokens(Long) - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
getConsumedTokens(T) - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
getConsumedTokens(Nothing) - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
getConsumedTokens(RemoteBucketState) - Method in class io.github.bucket4j.distributed.remote.commands.CreateSnapshotCommand
 
getConsumedTokens(EstimationProbe) - Method in class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
getConsumedTokens(Long) - Method in class io.github.bucket4j.distributed.remote.commands.GetAvailableTokensCommand
 
getConsumedTokens(BucketConfiguration) - Method in class io.github.bucket4j.distributed.remote.commands.GetConfigurationCommand
 
getConsumedTokens(MultiResult) - Method in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
getConsumedTokens(BucketConfiguration) - Method in class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
getConsumedTokens(Long) - Method in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
getConsumedTokens(Nothing) - Method in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
getConsumedTokens(ConsumptionProbe) - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
getConsumedTokens(Boolean) - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
getConsumedTokens(RemoteVerboseResult<T>) - Method in class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
getConsumedTokens(T) - Method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
getConsumedTokens() - Method in class io.github.bucket4j.distributed.remote.RemoteStat
 
getCurrentSize(int) - Method in interface io.github.bucket4j.BucketState
 
getCurrentSize(int) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
getCurrentSize(int) - Method in class io.github.bucket4j.BucketStateIEEE754
 
getData() - Method in interface io.github.bucket4j.distributed.proxy.generic.select_for_update.LockBasedTransaction
Returns the data by the key associated with this transaction.
getData() - Method in class io.github.bucket4j.distributed.remote.CommandResult
 
getDefault() - Static method in class io.github.bucket4j.distributed.proxy.ClientSideConfig
TODO
getDelayedNanos() - Method in class io.github.bucket4j.SimpleBucketListener
 
getHandleByTypeId(int) - Method in class io.github.bucket4j.distributed.serialization.SerializationHandles
 
getInitialTokens() - Method in class io.github.bucket4j.Bandwidth
 
getInterrupted() - Method in class io.github.bucket4j.SimpleBucketListener
 
getLastSyncTimeNanos() - Method in class io.github.bucket4j.distributed.proxy.optimization.predictive.Sampling
 
getLatest() - Static method in enum io.github.bucket4j.distributed.versioning.Versions
 
getLimit() - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
getListener() - Method in class io.github.bucket4j.AbstractBucket
 
getMathType() - Method in interface io.github.bucket4j.BucketState
 
getMathType() - Method in class io.github.bucket4j.BucketState64BitsInteger
 
getMathType() - Method in class io.github.bucket4j.BucketStateIEEE754
 
getMaxSamples() - Method in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
getMaxSupportedFormatNumber() - Method in class io.github.bucket4j.distributed.remote.UsageOfUnsupportedApiError
 
getMaxSupportedFormatNumber() - Method in exception io.github.bucket4j.distributed.versioning.UsageOfUnsupportedApiException
 
getMergeCount() - Method in class io.github.bucket4j.distributed.proxy.optimization.DefaultOptimizationListener
 
getMinSamples() - Method in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
getMinSupportedFormatNumber() - Method in class io.github.bucket4j.distributed.remote.UsageOfObsoleteApiError
 
getMinSupportedFormatNumber() - Method in exception io.github.bucket4j.distributed.versioning.UsageOfObsoleteApiException
 
getModifiedState() - Method in class io.github.bucket4j.distributed.proxy.generic.GenericEntry
 
getModifiedStateBytes() - Method in class io.github.bucket4j.distributed.proxy.generic.GenericEntry
 
getNanosSinceLastSync() - Method in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
getNanosToWaitForRefill() - Method in class io.github.bucket4j.ConsumptionProbe
Returns zero if ConsumptionProbe.isConsumed() returns true, else time in nanos which need to wait until requested amount of tokens will be refilled
getNanosToWaitForRefill() - Method in class io.github.bucket4j.EstimationProbe
Returns zero if EstimationProbe.canBeConsumed() returns true, else time in nanos which need to wait until requested amount of tokens will be refilled
getNanosToWaitForReset() - Method in class io.github.bucket4j.ConsumptionProbe
Time in nanos which need to wait until bucket will be fully refilled to its maximum
getNewConfiguration() - Method in class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
getNewConfiguration() - Method in exception io.github.bucket4j.IncompatibleConfigurationException
 
getNumber() - Method in interface io.github.bucket4j.distributed.versioning.Version
 
getNumber() - Method in enum io.github.bucket4j.distributed.versioning.Versions
 
getNumber() - Method in class io.github.bucket4j.distributed.versioning.Versions.UnknownVersion
 
getOldest() - Static method in enum io.github.bucket4j.distributed.versioning.Versions
 
getOperationTimeNanos() - Method in class io.github.bucket4j.distributed.remote.RemoteVerboseResult
 
getOperationTimeNanos() - Method in class io.github.bucket4j.VerboseResult
 
getParkedNanos() - Method in class io.github.bucket4j.SimpleBucketListener
 
getPreviousConfiguration() - Method in exception io.github.bucket4j.IncompatibleConfigurationException
 
getProxyConfiguration(K) - Method in class io.github.bucket4j.distributed.proxy.AbstractBackend
 
getProxyConfiguration(K) - Method in interface io.github.bucket4j.distributed.proxy.AsyncBackend
TODO Locates configuration of bucket which actually stored outside current JVM.
getProxyConfiguration(K) - Method in interface io.github.bucket4j.distributed.proxy.Backend
Locates configuration of bucket which actually stored outside current JVM.
getRawState() - Method in class io.github.bucket4j.distributed.remote.AbstractBinaryTransaction
 
getRefillPeriodNanos() - Method in class io.github.bucket4j.Bandwidth
 
getRefillTokens() - Method in class io.github.bucket4j.Bandwidth
 
getRejected() - Method in class io.github.bucket4j.SimpleBucketListener
 
getRemainingTokens() - Method in class io.github.bucket4j.ConsumptionProbe
Return the tokens remaining in the bucket
getRemainingTokens() - Method in class io.github.bucket4j.EstimationProbe
Return the tokens remaining in the bucket
getRemoteStat() - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
getRequestedFormatNumber() - Method in class io.github.bucket4j.distributed.remote.UsageOfObsoleteApiError
 
getRequestedFormatNumber() - Method in class io.github.bucket4j.distributed.remote.UsageOfUnsupportedApiError
 
getRequestedFormatNumber() - Method in exception io.github.bucket4j.distributed.versioning.UsageOfObsoleteApiException
 
getRequestedFormatNumber() - Method in exception io.github.bucket4j.distributed.versioning.UsageOfUnsupportedApiException
 
getResults() - Method in class io.github.bucket4j.distributed.remote.MultiResult
 
getResultTypeId() - Method in class io.github.bucket4j.distributed.remote.CommandResult
 
getRoundingError(int) - Method in interface io.github.bucket4j.BucketState
 
getRoundingError(int) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
getRoundingError(int) - Method in class io.github.bucket4j.BucketStateIEEE754
 
getSampleMaxAgeNanos() - Method in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.CreateSnapshotCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.GetAvailableTokensCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.GetConfigurationCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
getSerializationHandle() - Method in class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
getSerializationHandle() - Method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
getSerializedType() - Method in interface io.github.bucket4j.distributed.serialization.SerializationHandle
 
getSkipCount() - Method in class io.github.bucket4j.distributed.proxy.optimization.DefaultOptimizationListener
 
getState() - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
getState() - Method in class io.github.bucket4j.distributed.remote.RemoteVerboseResult
 
getState() - Method in class io.github.bucket4j.VerboseResult
 
getTargetCommand() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
getTargetCommand() - Method in class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
getTimeMeter() - Method in interface io.github.bucket4j.local.LocalBucket
 
getTimeMeter() - Method in class io.github.bucket4j.local.LockFreeBucket
 
getTimeMeter() - Method in class io.github.bucket4j.local.SynchronizedBucket
 
getTimeOfFirstRefillMillis() - Method in class io.github.bucket4j.Bandwidth
 
getTokensToAdd() - Method in class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
getTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
getTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
getTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
getTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
getTokensToConsume() - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
getTypeId() - Method in class io.github.bucket4j.distributed.remote.UnsupportedTypeError
 
getTypeId() - Method in interface io.github.bucket4j.distributed.serialization.SerializationHandle
 
getTypeId() - Method in exception io.github.bucket4j.distributed.versioning.UnsupportedTypeException
 
getUnsynchronizedTokens() - Method in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
getValue() - Method in class io.github.bucket4j.distributed.remote.RemoteVerboseResult
 
getValue() - Method in class io.github.bucket4j.VerboseResult
 
getWaitIfBusyNanosLimit() - Method in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
greedy(long, Duration) - Static method in class io.github.bucket4j.Refill
Creates the Refill that does refill of tokens in greedy manner, it will try to add the tokens to bucket as soon as possible.

H

hashCode() - Method in class io.github.bucket4j.Bandwidth
 
hashCode() - Method in class io.github.bucket4j.BucketConfiguration
 

I

IncompatibleConfigurationException - Exception in io.github.bucket4j
 
IncompatibleConfigurationException(BucketConfiguration, BucketConfiguration) - Constructor for exception io.github.bucket4j.IncompatibleConfigurationException
 
incrementMergeCount(int) - Method in class io.github.bucket4j.distributed.proxy.optimization.DefaultOptimizationListener
 
incrementMergeCount(int) - Method in class io.github.bucket4j.distributed.proxy.optimization.NopeOptimizationListener
 
incrementMergeCount(int) - Method in interface io.github.bucket4j.distributed.proxy.optimization.OptimizationListener
TODO
incrementSkipCount(int) - Method in class io.github.bucket4j.distributed.proxy.optimization.DefaultOptimizationListener
 
incrementSkipCount(int) - Method in class io.github.bucket4j.distributed.proxy.optimization.NopeOptimizationListener
 
incrementSkipCount(int) - Method in interface io.github.bucket4j.distributed.proxy.optimization.OptimizationListener
TODO
INFINITY_DURATION - Static variable in class io.github.bucket4j.AbstractBucket
 
INFINITY_DURATION - Static variable in class io.github.bucket4j.LimitChecker
 
INSTANCE - Static variable in class io.github.bucket4j.distributed.proxy.optimization.NopeOptimizationListener
 
INSTANCE - Static variable in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
INSTANCE - Static variable in class io.github.bucket4j.local.FakeLock
 
INSTANCE - Static variable in class io.github.bucket4j.Nothing
 
InternalSerializationHelper - Class in io.github.bucket4j.distributed.serialization
 
InternalSerializationHelper() - Constructor for class io.github.bucket4j.distributed.serialization.InternalSerializationHelper
 
intervally(long, Duration) - Static method in class io.github.bucket4j.Refill
Creates the Refill that does refill of tokens in intervally manner.
intervallyAligned(long, Duration, Instant, boolean) - Static method in class io.github.bucket4j.Refill
Creates the Refill that does refill of tokens in intervally manner.
intervallyAlignedRefillCompatibleOnlyWithWallClock() - Static method in class io.github.bucket4j.BucketExceptions
 
intervallyAlignedRefillWithAdaptiveInitialTokensIncompatipleWithManualSpecifiedInitialTokens() - Static method in class io.github.bucket4j.BucketExceptions
 
io.github.bucket4j - package io.github.bucket4j
 
io.github.bucket4j.distributed - package io.github.bucket4j.distributed
 
io.github.bucket4j.distributed.proxy - package io.github.bucket4j.distributed.proxy
 
io.github.bucket4j.distributed.proxy.generic - package io.github.bucket4j.distributed.proxy.generic
 
io.github.bucket4j.distributed.proxy.generic.compare_and_swap - package io.github.bucket4j.distributed.proxy.generic.compare_and_swap
 
io.github.bucket4j.distributed.proxy.generic.select_for_update - package io.github.bucket4j.distributed.proxy.generic.select_for_update
 
io.github.bucket4j.distributed.proxy.optimization - package io.github.bucket4j.distributed.proxy.optimization
 
io.github.bucket4j.distributed.proxy.optimization.batch - package io.github.bucket4j.distributed.proxy.optimization.batch
 
io.github.bucket4j.distributed.proxy.optimization.delay - package io.github.bucket4j.distributed.proxy.optimization.delay
 
io.github.bucket4j.distributed.proxy.optimization.predictive - package io.github.bucket4j.distributed.proxy.optimization.predictive
 
io.github.bucket4j.distributed.remote - package io.github.bucket4j.distributed.remote
 
io.github.bucket4j.distributed.remote.commands - package io.github.bucket4j.distributed.remote.commands
 
io.github.bucket4j.distributed.serialization - package io.github.bucket4j.distributed.serialization
 
io.github.bucket4j.distributed.versioning - package io.github.bucket4j.distributed.versioning
 
io.github.bucket4j.local - package io.github.bucket4j.local
 
io.github.bucket4j.util - package io.github.bucket4j.util
 
isAsyncModeSupported() - Method in interface io.github.bucket4j.distributed.proxy.Backend
TODO Describes whether or not this backend supports asynchronous mode.
isAsyncModeSupported() - Method in class io.github.bucket4j.distributed.proxy.generic.compare_and_swap.AbstractCompareAndSwapBasedBackend
 
isAsyncModeSupported() - Method in class io.github.bucket4j.distributed.proxy.generic.select_for_update.AbstractLockBasedBackend
 
isBucketNotFound() - Method in class io.github.bucket4j.distributed.remote.CommandResult
 
isCompatible(BucketConfiguration) - Method in class io.github.bucket4j.BucketConfiguration
 
isConsumed() - Method in class io.github.bucket4j.ConsumptionProbe
Flag describes result of consumption operation.
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.CreateSnapshotCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.GetAvailableTokensCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.GetConfigurationCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
isImmediateSyncRequired(long, long) - Method in class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
isImmediateSyncRequired(long, long) - Method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
isInitializationCommand() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
isInitializationCommand() - Method in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
isInitializationCommand() - Method in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
isInitializationCommand() - Method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
isIntervallyAligned() - Method in class io.github.bucket4j.Bandwidth
 
isModified() - Method in class io.github.bucket4j.distributed.proxy.generic.GenericEntry
 
isNeedToExecuteRemoteImmediately(long) - Method in class io.github.bucket4j.distributed.proxy.optimization.predictive.Sampling
 
isRefillIntervally() - Method in class io.github.bucket4j.Bandwidth
 
isStateModified() - Method in class io.github.bucket4j.distributed.remote.commands.BucketEntryWrapper
 
isUseAdaptiveInitialTokens() - Method in class io.github.bucket4j.Bandwidth
 
isWallClockBased() - Method in interface io.github.bucket4j.TimeMeter
Returns true if implementation of clock behaves the similar way as System.currentTimeMillis(), in other words if implementation can be used as wall clock.

L

LimitChecker - Class in io.github.bucket4j
 
LimitChecker() - Constructor for class io.github.bucket4j.LimitChecker
 
LocalBucket - Interface in io.github.bucket4j.local
Represents the bucket inside current JVM.
LocalBucketBuilder - Class in io.github.bucket4j.local
This builder creates in-memory buckets (LockFreeBucket).
LocalBucketBuilder() - Constructor for class io.github.bucket4j.local.LocalBucketBuilder
 
lock() - Method in interface io.github.bucket4j.distributed.proxy.generic.select_for_update.LockBasedTransaction
Locks data by the key associated with this transaction.
lock() - Method in class io.github.bucket4j.local.FakeLock
 
LockBasedTransaction - Interface in io.github.bucket4j.distributed.proxy.generic.select_for_update
TODO
lockExclusivelyOrEnqueue(RemoteCommand<?>) - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.TaskQueue
 
LockFreeBucket - Class in io.github.bucket4j.local
 
LockFreeBucket(BucketConfiguration, MathType, TimeMeter) - Constructor for class io.github.bucket4j.local.LockFreeBucket
 
lockInterruptibly() - Method in class io.github.bucket4j.local.FakeLock
 
LockResult - Enum in io.github.bucket4j.distributed.proxy.generic.select_for_update
 
LONG_HANDLE - Static variable in class io.github.bucket4j.distributed.serialization.PrimitiveSerializationHandles
 

M

map(Function<T, R>) - Method in class io.github.bucket4j.distributed.remote.RemoteVerboseResult
 
map(Function<T, R>) - Method in class io.github.bucket4j.VerboseResult
 
MathType - Enum in io.github.bucket4j
 
max(Version, Version) - Static method in interface io.github.bucket4j.distributed.versioning.Version
 
MAX_VALUE - Static variable in class io.github.bucket4j.distributed.remote.CommandResult
 
maxSamples - Variable in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
maxUnsynchronizedTimeoutNanos - Variable in class io.github.bucket4j.distributed.proxy.optimization.DelayParameters
 
maxUnsynchronizedTokens - Variable in class io.github.bucket4j.distributed.proxy.optimization.DelayParameters
 
merge(SerializationHandle<?>...) - Method in class io.github.bucket4j.distributed.serialization.SerializationHandles
 
minSamples - Variable in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
MultiCommand - Class in io.github.bucket4j.distributed.remote.commands
 
MultiCommand(List<RemoteCommand<?>>) - Constructor for class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
MultiResult - Class in io.github.bucket4j.distributed.remote
 
MultiResult(List<CommandResult<?>>) - Constructor for class io.github.bucket4j.distributed.remote.MultiResult
 
MutableBucketEntry - Interface in io.github.bucket4j.distributed.remote
TODO javadocs

N

NEED_TO_EXECUTE_NEXT_BATCH - Static variable in class io.github.bucket4j.distributed.proxy.optimization.batch.WaitingTask
 
newCondition() - Method in class io.github.bucket4j.local.FakeLock
 
NONE_OPTIMIZED - Static variable in interface io.github.bucket4j.distributed.proxy.optimization.Optimization
 
nonPositiveCapacity(long) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositiveFixedRefillInterval(Duration) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositiveInitialTokens(long) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositiveLimitToSync(long) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositiveNanosToWait(long) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositivePeriod(long) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositivePeriodTokens(long) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositiveTimeOfFirstRefill(Instant) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositiveTokensLimitToSync(long) - Static method in class io.github.bucket4j.BucketExceptions
 
nonPositiveTokensToConsume(long) - Static method in class io.github.bucket4j.BucketExceptions
 
NOPE - Static variable in interface io.github.bucket4j.BucketListener
The default listener that do nothing.
NopeOptimizationListener - Class in io.github.bucket4j.distributed.proxy.optimization
 
NopeOptimizationListener() - Constructor for class io.github.bucket4j.distributed.proxy.optimization.NopeOptimizationListener
 
NOTHING - Static variable in class io.github.bucket4j.distributed.remote.CommandResult
 
Nothing - Class in io.github.bucket4j
 
Nothing() - Constructor for class io.github.bucket4j.Nothing
 
NULL_HANDLE - Static variable in class io.github.bucket4j.distributed.serialization.PrimitiveSerializationHandles
 
nullBandwidth() - Static method in class io.github.bucket4j.BucketExceptions
 
nullBandwidthRefill() - Static method in class io.github.bucket4j.BucketExceptions
 
nullConfiguration() - Static method in class io.github.bucket4j.BucketExceptions
 
nullConfigurationFuture() - Static method in class io.github.bucket4j.BucketExceptions
 
nullConfigurationSupplier() - Static method in class io.github.bucket4j.BucketExceptions
 
nullFixedRefillInterval() - Static method in class io.github.bucket4j.BucketExceptions
 
nullListener() - Static method in class io.github.bucket4j.BucketExceptions
 
nullRefillPeriod() - Static method in class io.github.bucket4j.BucketExceptions
 
nullScheduler() - Static method in class io.github.bucket4j.BucketExceptions
 
nullSynchronizationStrategy() - Static method in class io.github.bucket4j.BucketExceptions
 
nullTimeMeter() - Static method in class io.github.bucket4j.BucketExceptions
 

O

of(long, Duration) - Static method in class io.github.bucket4j.Refill
Deprecated.
onConsumed(long) - Method in interface io.github.bucket4j.BucketListener
This method is called whenever tokens is consumed.
onConsumed(long) - Method in class io.github.bucket4j.SimpleBucketListener
 
onDelayed(long) - Method in interface io.github.bucket4j.BucketListener
This method is called each time when delayed task was submit to ScheduledExecutorService because of wait for tokens refill in result of interaction with ScheduledBucket
onDelayed(long) - Method in class io.github.bucket4j.SimpleBucketListener
 
onInterrupted(InterruptedException) - Method in interface io.github.bucket4j.BucketListener
This method is called each time when thread was interrupted during the wait of tokens refill in result of interaction with BlockingBucket
onInterrupted(InterruptedException) - Method in class io.github.bucket4j.SimpleBucketListener
 
onParked(long) - Method in interface io.github.bucket4j.BucketListener
This method is called each time when thread was parked for wait of tokens refill in result of interaction with BlockingBucket
onParked(long) - Method in class io.github.bucket4j.SimpleBucketListener
 
onRejected(long) - Method in interface io.github.bucket4j.BucketListener
This method is called whenever consumption request for tokens is rejected.
onRejected(long) - Method in class io.github.bucket4j.SimpleBucketListener
 
Optimization - Interface in io.github.bucket4j.distributed.proxy.optimization
 
OptimizationListener - Interface in io.github.bucket4j.distributed.proxy.optimization
TODO
Optimizations - Class in io.github.bucket4j.distributed.proxy.optimization
 
Optimizations() - Constructor for class io.github.bucket4j.distributed.proxy.optimization.Optimizations
 

P

park(long) - Method in interface io.github.bucket4j.BlockingStrategy
Park current thread to required duration of nanoseconds.
PARKING - Static variable in interface io.github.bucket4j.BlockingStrategy
 
PARKING - Static variable in interface io.github.bucket4j.UninterruptibleBlockingStrategy
 
parkUninterruptibly(long) - Method in interface io.github.bucket4j.UninterruptibleBlockingStrategy
Parks current thread to required duration of nanoseconds ignoring all interrupts, if interrupt was happen then interruption flag will be restored on the current thread.
predictedConsumptionByOthersSinceLastSync(long) - Method in class io.github.bucket4j.distributed.proxy.optimization.predictive.Sampling
 
predicting(DelayParameters) - Static method in class io.github.bucket4j.distributed.proxy.optimization.Optimizations
 
predicting(DelayParameters, PredictionParameters) - Static method in class io.github.bucket4j.distributed.proxy.optimization.Optimizations
 
PredictionParameters - Class in io.github.bucket4j.distributed.proxy.optimization
 
PredictionParameters(int, int, Duration) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
PredictionParameters(int, int, long) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
PredictiveOptimization - Class in io.github.bucket4j.distributed.proxy.optimization.predictive
 
PredictiveOptimization(PredictionParameters, DelayParameters, OptimizationListener, TimeMeter) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.predictive.PredictiveOptimization
 
previous - Variable in class io.github.bucket4j.distributed.proxy.optimization.batch.WaitingTask
 
primitiveHandlesById - Static variable in class io.github.bucket4j.distributed.serialization.PrimitiveSerializationHandles
 
PrimitiveSerializationHandles - Class in io.github.bucket4j.distributed.serialization
 
PrimitiveSerializationHandles() - Constructor for class io.github.bucket4j.distributed.serialization.PrimitiveSerializationHandles
 

R

readBoolean(DataInput) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
readBoolean(S) - Method in interface io.github.bucket4j.distributed.serialization.DeserializationAdapter
 
readByte(DataInput) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
readByte(S) - Method in interface io.github.bucket4j.distributed.serialization.DeserializationAdapter
 
readDoubleArray(DataInput) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
readDoubleArray(S) - Method in interface io.github.bucket4j.distributed.serialization.DeserializationAdapter
 
readInt(DataInput) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
readInt(S) - Method in interface io.github.bucket4j.distributed.serialization.DeserializationAdapter
 
readLong(DataInput) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
readLong(S) - Method in interface io.github.bucket4j.distributed.serialization.DeserializationAdapter
 
readLongArray(DataInput) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
readLongArray(S) - Method in interface io.github.bucket4j.distributed.serialization.DeserializationAdapter
 
RecoveryStrategy - Enum in io.github.bucket4j.distributed.proxy
Specifies the reaction which should be applied in case of previously saved state of bucket has been lost.
Refill - Class in io.github.bucket4j
Specifies the speed of tokens regeneration.
refillAllBandwidth(Bandwidth[], long) - Method in interface io.github.bucket4j.BucketState
 
refillAllBandwidth(Bandwidth[], long) - Method in class io.github.bucket4j.BucketState64BitsInteger
 
refillAllBandwidth(Bandwidth[], long) - Method in class io.github.bucket4j.BucketStateIEEE754
 
refillAllBandwidth(long) - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
rejected(long, long, long) - Static method in class io.github.bucket4j.ConsumptionProbe
 
releaseTransaction(CompareAndSwapBasedTransaction) - Method in class io.github.bucket4j.distributed.proxy.generic.compare_and_swap.AbstractCompareAndSwapBasedBackend
 
releaseTransaction(LockBasedTransaction) - Method in class io.github.bucket4j.distributed.proxy.generic.select_for_update.AbstractLockBasedBackend
 
rememberRemoteCommandResult(long, long, long) - Method in class io.github.bucket4j.distributed.proxy.optimization.predictive.Sampling
 
RemoteAsyncBucketBuilder<K> - Interface in io.github.bucket4j.distributed.proxy
TODO
RemoteBucketBuilder<K> - Interface in io.github.bucket4j.distributed.proxy
TODO
RemoteBucketState - Class in io.github.bucket4j.distributed.remote
 
RemoteBucketState(BucketConfiguration, BucketState, RemoteStat) - Constructor for class io.github.bucket4j.distributed.remote.RemoteBucketState
 
RemoteCommand<T> - Interface in io.github.bucket4j.distributed.remote
 
RemoteStat - Class in io.github.bucket4j.distributed.remote
 
RemoteStat(long) - Constructor for class io.github.bucket4j.distributed.remote.RemoteStat
 
RemoteVerboseResult<T> - Class in io.github.bucket4j.distributed.remote
Intention of this class is to provide wrapper around results returned by any method of VerboseBucket and AsyncVerboseBucket.
RemoteVerboseResult(long, int, T, RemoteBucketState) - Constructor for class io.github.bucket4j.distributed.remote.RemoteVerboseResult
 
replaceConfiguration(BucketConfiguration) - Method in class io.github.bucket4j.AbstractBucket
 
replaceConfiguration(BucketConfiguration) - Method in interface io.github.bucket4j.Bucket
Replaces configuration of this bucket instance.
replaceConfiguration(BucketConfiguration) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Asynchronous version of Bucket.replaceConfiguration(BucketConfiguration), follows the same rules and semantic.
replaceConfiguration(BucketConfiguration) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
replaceConfiguration(BucketConfiguration) - Method in interface io.github.bucket4j.distributed.AsyncVerboseBucket
replaceConfiguration(BucketConfiguration) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
replaceConfiguration(BucketConfiguration) - Method in interface io.github.bucket4j.VerboseBucket
replaceConfigurationImpl(BucketConfiguration) - Method in class io.github.bucket4j.AbstractBucket
 
replaceConfigurationImpl(BucketConfiguration) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
replaceConfigurationImpl(BucketConfiguration) - Method in class io.github.bucket4j.local.LockFreeBucket
 
replaceConfigurationImpl(BucketConfiguration) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
replaceConfigurationOrReturnPrevious(BucketConfiguration) - Method in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
ReplaceConfigurationOrReturnPreviousCommand - Class in io.github.bucket4j.distributed.remote.commands
 
ReplaceConfigurationOrReturnPreviousCommand(BucketConfiguration) - Constructor for class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
replaceConfigurationVerboseImpl(BucketConfiguration) - Method in class io.github.bucket4j.AbstractBucket
 
replaceConfigurationVerboseImpl(BucketConfiguration) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
replaceConfigurationVerboseImpl(BucketConfiguration) - Method in class io.github.bucket4j.local.LockFreeBucket
 
replaceConfigurationVerboseImpl(BucketConfiguration) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
Request<T> - Class in io.github.bucket4j.distributed.remote
 
Request(RemoteCommand<T>, Version, Long) - Constructor for class io.github.bucket4j.distributed.remote.Request
 
reservationOverflow() - Static method in class io.github.bucket4j.BucketExceptions
 
ReserveAndCalculateTimeToSleepCommand - Class in io.github.bucket4j.distributed.remote.commands
 
ReserveAndCalculateTimeToSleepCommand(long, long) - Constructor for class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
reserveAndCalculateTimeToSleepImpl(long, long) - Method in class io.github.bucket4j.AbstractBucket
 
reserveAndCalculateTimeToSleepImpl(long, long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
reserveAndCalculateTimeToSleepImpl(long, long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
reserveAndCalculateTimeToSleepImpl(long, long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
restrictionsNotSpecified() - Static method in class io.github.bucket4j.BucketExceptions
 
rollback() - Method in interface io.github.bucket4j.distributed.proxy.generic.select_for_update.LockBasedTransaction
Rollbacks transaction if underlying storage requires transactions

S

sampleMaxAgeNanos - Variable in class io.github.bucket4j.distributed.proxy.optimization.PredictionParameters
 
Sampling - Class in io.github.bucket4j.distributed.proxy.optimization.predictive
 
Sampling(PredictionParameters) - Constructor for class io.github.bucket4j.distributed.proxy.optimization.predictive.Sampling
 
ScheduledBucket - Interface in io.github.bucket4j
Provides TODO async API for bucket that allows to use bucket as async scheduler.
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.Bandwidth
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.BucketConfiguration
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.BucketState64BitsInteger
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.BucketStateIEEE754
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.ConsumptionProbe
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.BucketNotFoundError
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.CommandResult
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.AddTokensCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.ConsumeAsMuchAsPossibleCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.ConsumeIgnoringRateLimitsCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateAndExecuteCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.CreateInitialStateCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.CreateSnapshotCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.EstimateAbilityToConsumeCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.GetAvailableTokensCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.GetConfigurationCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.MultiCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.ReplaceConfigurationOrReturnPreviousCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.ReserveAndCalculateTimeToSleepCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.MultiResult
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.RemoteBucketState
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.RemoteStat
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.RemoteVerboseResult
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.Request
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.UnsupportedTypeError
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.UsageOfObsoleteApiError
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.distributed.remote.UsageOfUnsupportedApiError
 
SERIALIZATION_HANDLE - Static variable in class io.github.bucket4j.EstimationProbe
 
SerializationAdapter<T> - Interface in io.github.bucket4j.distributed.serialization
 
SerializationHandle<T> - Interface in io.github.bucket4j.distributed.serialization
 
SerializationHandles - Class in io.github.bucket4j.distributed.serialization
 
SerializationHandles(Collection<SerializationHandle<?>>) - Constructor for class io.github.bucket4j.distributed.serialization.SerializationHandles
 
serialize(SerializationAdapter<O>, O, BucketState, Version) - Static method in interface io.github.bucket4j.BucketState
 
serialize(SerializationAdapter<O>, O, RemoteCommand<?>, Version) - Static method in interface io.github.bucket4j.distributed.remote.RemoteCommand
 
serialize(SerializationAdapter<O>, O, T, Version) - Method in interface io.github.bucket4j.distributed.serialization.SerializationHandle
 
serializeRequest(Request<?>) - Static method in class io.github.bucket4j.distributed.serialization.InternalSerializationHelper
 
serializeResult(CommandResult<?>, Version) - Static method in class io.github.bucket4j.distributed.serialization.InternalSerializationHelper
 
serializeState(RemoteBucketState, Version) - Static method in class io.github.bucket4j.distributed.serialization.InternalSerializationHelper
 
set(RemoteBucketState) - Method in class io.github.bucket4j.distributed.proxy.generic.GenericEntry
 
set(RemoteBucketState) - Method in class io.github.bucket4j.distributed.remote.AbstractBinaryTransaction
 
set(RemoteBucketState) - Method in class io.github.bucket4j.distributed.remote.commands.BucketEntryWrapper
 
set(RemoteBucketState) - Method in interface io.github.bucket4j.distributed.remote.MutableBucketEntry
 
setRawState(byte[]) - Method in class io.github.bucket4j.distributed.remote.AbstractBinaryTransaction
 
simple(long, Duration) - Static method in class io.github.bucket4j.Bandwidth
Specifies simple limitation capacity tokens per period time window.
SimpleBucketListener - Class in io.github.bucket4j
 
SimpleBucketListener() - Constructor for class io.github.bucket4j.SimpleBucketListener
 
smooth(long, Duration) - Static method in class io.github.bucket4j.Refill
Deprecated.
success(R, SerializationHandle) - Static method in class io.github.bucket4j.distributed.remote.CommandResult
 
success(R, int) - Static method in class io.github.bucket4j.distributed.remote.CommandResult
 
syncByCondition(long, Duration) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
TODO javadocs
syncByCondition(long, Duration) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
syncByCondition(long, Duration) - Method in interface io.github.bucket4j.distributed.BucketProxy
 
syncByCondition(long, Duration) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
syncByCondition(long, Duration) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
SyncCommand - Class in io.github.bucket4j.distributed.remote.commands
 
SyncCommand(long, long) - Constructor for class io.github.bucket4j.distributed.remote.commands.SyncCommand
 
SynchronizationStrategy - Enum in io.github.bucket4j.local
Defines the strategy of synchronization which need to be applied to prevent data-races in multithreading usage scenario.
SynchronizedBucket - Class in io.github.bucket4j.local
 
SynchronizedBucket(BucketConfiguration, MathType, TimeMeter) - Constructor for class io.github.bucket4j.local.SynchronizedBucket
 
syncImmediately() - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
TODO javadocs
syncImmediately() - Method in interface io.github.bucket4j.distributed.BucketProxy
TODO javadocs
SYSTEM_MILLISECONDS - Static variable in interface io.github.bucket4j.TimeMeter
The implementation of TimeMeter which works around System.currentTimeMillis()
SYSTEM_NANOTIME - Static variable in interface io.github.bucket4j.TimeMeter
The implementation of TimeMeter which works around System.nanoTime()

T

takeAllWaitingTasksOrFreeLock() - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.TaskQueue
 
TaskQueue - Class in io.github.bucket4j.distributed.proxy.optimization.batch
 
TaskQueue() - Constructor for class io.github.bucket4j.distributed.proxy.optimization.batch.TaskQueue
 
TimeMeter - Interface in io.github.bucket4j
An abstraction over time measurement.
toListenable(BucketListener) - Method in interface io.github.bucket4j.Bucket
Returns new copy of this bucket instance decorated by listener.
toListenable(BucketListener) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Returns new copy of this bucket instance decorated by listener.
toListenable(BucketListener) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
toListenable(BucketListener) - Method in interface io.github.bucket4j.distributed.BucketProxy
 
toListenable(BucketListener) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
toListenable(BucketListener) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
toListenable(BucketListener) - Method in class io.github.bucket4j.local.LockFreeBucket
 
toListenable(BucketListener) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
tooHighRefillRate(long, long) - Static method in class io.github.bucket4j.BucketExceptions
 
toString() - Method in class io.github.bucket4j.Bandwidth
 
toString() - Method in class io.github.bucket4j.BucketConfiguration
 
toString() - Method in class io.github.bucket4j.BucketState64BitsInteger
 
toString() - Method in class io.github.bucket4j.BucketStateIEEE754
 
toString() - Method in class io.github.bucket4j.ConfigurationBuilder
 
toString() - Method in class io.github.bucket4j.ConsumptionProbe
 
toString() - Method in class io.github.bucket4j.EstimationProbe
 
toString() - Method in class io.github.bucket4j.local.LockFreeBucket
 
toString() - Method in class io.github.bucket4j.local.SynchronizedBucket
 
toString() - Method in class io.github.bucket4j.Refill
 
TRUE - Static variable in class io.github.bucket4j.distributed.remote.CommandResult
 
tryConsume(long) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsume(long, long, BlockingStrategy) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsume(long, long, ScheduledExecutorService) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsume(long, long, BlockingStrategy) - Method in interface io.github.bucket4j.BlockingBucket
Tries to consume a specified number of tokens from the bucket.
tryConsume(long, Duration, BlockingStrategy) - Method in interface io.github.bucket4j.BlockingBucket
This is just overloaded equivalent of BlockingBucket.tryConsume(long, long, BlockingStrategy)
tryConsume(long, long) - Method in interface io.github.bucket4j.BlockingBucket
This is just overloaded equivalent of BlockingBucket.tryConsume(long, long, BlockingStrategy)
tryConsume(long, Duration) - Method in interface io.github.bucket4j.BlockingBucket
This is just overloaded equivalent of BlockingBucket.tryConsume(long, long, BlockingStrategy)
tryConsume(long) - Method in interface io.github.bucket4j.Bucket
Tries to consume a specified number of tokens from this bucket.
tryConsume(long) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Asynchronous version of Bucket.tryConsume(long), follows the same semantic.
tryConsume(long) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
tryConsume(long) - Method in interface io.github.bucket4j.distributed.AsyncVerboseBucket
Does the same that Bucket.tryConsume(long)
tryConsume(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
tryConsume(long, long, ScheduledExecutorService) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
tryConsume(long, long, ScheduledExecutorService) - Method in interface io.github.bucket4j.ScheduledBucket
Tries to consume the specified number of tokens from the bucket.
tryConsume(long, Duration, ScheduledExecutorService) - Method in interface io.github.bucket4j.ScheduledBucket
tryConsume(long) - Method in interface io.github.bucket4j.VerboseBucket
Does the same that Bucket.tryConsume(long)
tryConsumeAndReturnRemaining(long) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsumeAndReturnRemaining(long) - Method in interface io.github.bucket4j.Bucket
Tries to consume a specified number of tokens from this bucket.
tryConsumeAndReturnRemaining(long) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Asynchronous version of Bucket.tryConsumeAndReturnRemaining(long), follows the same semantic.
tryConsumeAndReturnRemaining(long) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
tryConsumeAndReturnRemaining(long) - Method in interface io.github.bucket4j.distributed.AsyncVerboseBucket
tryConsumeAndReturnRemaining(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
tryConsumeAndReturnRemaining(long) - Method in interface io.github.bucket4j.VerboseBucket
TryConsumeAndReturnRemainingTokensCommand - Class in io.github.bucket4j.distributed.remote.commands
 
TryConsumeAndReturnRemainingTokensCommand(long) - Constructor for class io.github.bucket4j.distributed.remote.commands.TryConsumeAndReturnRemainingTokensCommand
 
tryConsumeAndReturnRemainingTokensImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsumeAndReturnRemainingTokensImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
tryConsumeAndReturnRemainingTokensImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
tryConsumeAndReturnRemainingTokensImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
tryConsumeAndReturnRemainingTokensVerboseImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsumeAndReturnRemainingTokensVerboseImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
tryConsumeAndReturnRemainingTokensVerboseImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
tryConsumeAndReturnRemainingTokensVerboseImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
tryConsumeAsMuchAsPossible(long) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsumeAsMuchAsPossible() - Method in class io.github.bucket4j.AbstractBucket
 
tryConsumeAsMuchAsPossible() - Method in interface io.github.bucket4j.Bucket
Tries to consume as much tokens from this bucket as available at the moment of invocation.
tryConsumeAsMuchAsPossible(long) - Method in interface io.github.bucket4j.Bucket
Tries to consume as much tokens from bucket as available in the bucket at the moment of invocation, but tokens which should be consumed is limited by limit.
tryConsumeAsMuchAsPossible() - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Asynchronous version of Bucket.tryConsumeAsMuchAsPossible(), follows the same semantic.
tryConsumeAsMuchAsPossible(long) - Method in interface io.github.bucket4j.distributed.AsyncBucketProxy
Asynchronous version of Bucket.tryConsumeAsMuchAsPossible(long), follows the same semantic.
tryConsumeAsMuchAsPossible() - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
tryConsumeAsMuchAsPossible(long) - Method in class io.github.bucket4j.distributed.AsyncBucketProxyAdapter
 
tryConsumeAsMuchAsPossible() - Method in interface io.github.bucket4j.distributed.AsyncVerboseBucket
tryConsumeAsMuchAsPossible(long) - Method in interface io.github.bucket4j.distributed.AsyncVerboseBucket
tryConsumeAsMuchAsPossible() - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
tryConsumeAsMuchAsPossible(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultAsyncBucketProxy
 
tryConsumeAsMuchAsPossible() - Method in interface io.github.bucket4j.VerboseBucket
tryConsumeAsMuchAsPossible(long) - Method in interface io.github.bucket4j.VerboseBucket
TryConsumeCommand - Class in io.github.bucket4j.distributed.remote.commands
 
TryConsumeCommand(long) - Constructor for class io.github.bucket4j.distributed.remote.commands.TryConsumeCommand
 
tryConsumeImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsumeImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
tryConsumeImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
tryConsumeImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
tryConsumeUninterruptibly(long, long, UninterruptibleBlockingStrategy) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsumeUninterruptibly(long, long, UninterruptibleBlockingStrategy) - Method in interface io.github.bucket4j.BlockingBucket
Has same semantic with BlockingBucket.tryConsume(long, long, BlockingStrategy) but ignores interrupts(just restores interruption flag on exit).
tryConsumeUninterruptibly(long, Duration, UninterruptibleBlockingStrategy) - Method in interface io.github.bucket4j.BlockingBucket
tryConsumeUninterruptibly(long, long) - Method in interface io.github.bucket4j.BlockingBucket
tryConsumeUninterruptibly(long, Duration) - Method in interface io.github.bucket4j.BlockingBucket
tryConsumeVerboseImpl(long) - Method in class io.github.bucket4j.AbstractBucket
 
tryConsumeVerboseImpl(long) - Method in class io.github.bucket4j.distributed.proxy.DefaultBucketProxy
 
tryConsumeVerboseImpl(long) - Method in class io.github.bucket4j.local.LockFreeBucket
 
tryConsumeVerboseImpl(long) - Method in class io.github.bucket4j.local.SynchronizedBucket
 
tryLock() - Method in class io.github.bucket4j.local.FakeLock
 
tryLock(long, TimeUnit) - Method in class io.github.bucket4j.local.FakeLock
 

U

UninterruptibleBlockingStrategy - Interface in io.github.bucket4j
Specifies the way to block current thread to amount of time required to refill missed number of tokens in the bucket.
UnknownVersion(int) - Constructor for class io.github.bucket4j.distributed.versioning.Versions.UnknownVersion
 
UNLIMITED_AMOUNT - Static variable in class io.github.bucket4j.AbstractBucket
 
UNLIMITED_AMOUNT - Static variable in class io.github.bucket4j.LimitChecker
 
unlock() - Method in interface io.github.bucket4j.distributed.proxy.generic.select_for_update.LockBasedTransaction
Unlocks data by the key associated with this transaction.
unlock() - Method in class io.github.bucket4j.local.FakeLock
 
unsupportedType(int) - Static method in class io.github.bucket4j.distributed.remote.CommandResult
 
UnsupportedTypeError - Class in io.github.bucket4j.distributed.remote
 
UnsupportedTypeError(int) - Constructor for class io.github.bucket4j.distributed.remote.UnsupportedTypeError
 
UnsupportedTypeException - Exception in io.github.bucket4j.distributed.versioning
 
UnsupportedTypeException(int) - Constructor for exception io.github.bucket4j.distributed.versioning.UnsupportedTypeException
 
update(byte[]) - Method in interface io.github.bucket4j.distributed.proxy.generic.select_for_update.LockBasedTransaction
Updates the data by the key associated with this transaction.
UsageOfObsoleteApiError - Class in io.github.bucket4j.distributed.remote
 
UsageOfObsoleteApiError(int, int) - Constructor for class io.github.bucket4j.distributed.remote.UsageOfObsoleteApiError
 
usageOfObsoleteApiException(int, int) - Static method in class io.github.bucket4j.distributed.remote.CommandResult
 
UsageOfObsoleteApiException - Exception in io.github.bucket4j.distributed.versioning
 
UsageOfObsoleteApiException(int, int) - Constructor for exception io.github.bucket4j.distributed.versioning.UsageOfObsoleteApiException
 
UsageOfUnsupportedApiError - Class in io.github.bucket4j.distributed.remote
 
UsageOfUnsupportedApiError(int, int) - Constructor for class io.github.bucket4j.distributed.remote.UsageOfUnsupportedApiError
 
usageOfUnsupportedApiException(int, int) - Static method in class io.github.bucket4j.distributed.remote.CommandResult
 
UsageOfUnsupportedApiException - Exception in io.github.bucket4j.distributed.versioning
 
UsageOfUnsupportedApiException(int, int) - Constructor for exception io.github.bucket4j.distributed.versioning.UsageOfUnsupportedApiException
 

V

valueOf(String) - Static method in enum io.github.bucket4j.distributed.proxy.generic.select_for_update.LockResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.bucket4j.distributed.proxy.RecoveryStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.bucket4j.distributed.versioning.Versions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.bucket4j.local.SynchronizationStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.bucket4j.MathType
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.github.bucket4j.distributed.proxy.generic.select_for_update.LockResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.bucket4j.distributed.proxy.RecoveryStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.bucket4j.distributed.versioning.Versions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.bucket4j.local.SynchronizationStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.bucket4j.MathType
Returns an array containing the constants of this enum type, in the order they are declared.
VerboseBucket - Interface in io.github.bucket4j
Intent of this interface is to provide the verbose version of Bucket API.
VerboseCommand<T> - Class in io.github.bucket4j.distributed.remote.commands
 
VerboseCommand(RemoteCommand<T>) - Constructor for class io.github.bucket4j.distributed.remote.commands.VerboseCommand
 
VerboseResult<T> - Class in io.github.bucket4j
Intention of this class is to provide wrapper around results returned by any method of VerboseBucket and AsyncVerboseBucket.
VerboseResult(long, T, BucketConfiguration, BucketState) - Constructor for class io.github.bucket4j.VerboseResult
 
Version - Interface in io.github.bucket4j.distributed.versioning
 
Versions - Enum in io.github.bucket4j.distributed.versioning
 
Versions.UnknownVersion - Class in io.github.bucket4j.distributed.versioning
 

W

WaitingTask - Class in io.github.bucket4j.distributed.proxy.optimization.batch
 
waitUninterruptedly() - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.WaitingTask
 
wakeupAnyThreadFromNextBatchOrFreeLock() - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.TaskQueue
 
withClientClock(TimeMeter) - Static method in class io.github.bucket4j.distributed.proxy.ClientSideConfig
TODO
withClientClockAndCompatibility(TimeMeter, Version) - Static method in class io.github.bucket4j.distributed.proxy.ClientSideConfig
 
withCustomTimePrecision(TimeMeter) - Method in class io.github.bucket4j.local.LocalBucketBuilder
Specifies customTimeMeter time meter for buckets that will be created by this builder.
withInitialTokens(long) - Method in class io.github.bucket4j.Bandwidth
By default new created bandwidth has amount tokens that equals its capacity.
withListener(OptimizationListener) - Method in class io.github.bucket4j.distributed.proxy.optimization.batch.BatchingOptimization
 
withListener(OptimizationListener) - Method in class io.github.bucket4j.distributed.proxy.optimization.delay.DelayOptimization
 
withListener(OptimizationListener) - Method in interface io.github.bucket4j.distributed.proxy.optimization.Optimization
 
withListener(OptimizationListener) - Method in class io.github.bucket4j.distributed.proxy.optimization.predictive.PredictiveOptimization
 
withMath(MathType) - Method in class io.github.bucket4j.local.LocalBucketBuilder
 
withMillisecondPrecision() - Method in class io.github.bucket4j.local.LocalBucketBuilder
Specifies TimeMeter.SYSTEM_MILLISECONDS as time meter for buckets that will be created by this builder.
withNanosecondPrecision() - Method in class io.github.bucket4j.local.LocalBucketBuilder
Specifies TimeMeter.SYSTEM_NANOTIME as time meter for buckets that will be created by this builder.
withOptimization(Optimization) - Method in interface io.github.bucket4j.distributed.proxy.RemoteAsyncBucketBuilder
TODO
withOptimization(Optimization) - Method in interface io.github.bucket4j.distributed.proxy.RemoteBucketBuilder
TODO
withRecoveryStrategy(RecoveryStrategy) - Method in interface io.github.bucket4j.distributed.proxy.RemoteAsyncBucketBuilder
TODO
withRecoveryStrategy(RecoveryStrategy) - Method in interface io.github.bucket4j.distributed.proxy.RemoteBucketBuilder
TODO
withSynchronizationStrategy(SynchronizationStrategy) - Method in class io.github.bucket4j.local.LocalBucketBuilder
Specifies synchronizationStrategy for buckets that will be created by this builder.
writeBoolean(DataOutput, boolean) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
writeBoolean(T, boolean) - Method in interface io.github.bucket4j.distributed.serialization.SerializationAdapter
 
writeByte(DataOutput, byte) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
writeByte(T, byte) - Method in interface io.github.bucket4j.distributed.serialization.SerializationAdapter
 
writeDoubleArray(DataOutput, double[]) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
writeDoubleArray(T, double[]) - Method in interface io.github.bucket4j.distributed.serialization.SerializationAdapter
 
writeInt(DataOutput, int) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
writeInt(T, int) - Method in interface io.github.bucket4j.distributed.serialization.SerializationAdapter
 
writeLong(DataOutput, long) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
writeLong(T, long) - Method in interface io.github.bucket4j.distributed.serialization.SerializationAdapter
 
writeLongArray(DataOutput, long[]) - Method in class io.github.bucket4j.distributed.serialization.DataOutputSerializationAdapter
 
writeLongArray(T, long[]) - Method in interface io.github.bucket4j.distributed.serialization.SerializationAdapter
 

Z

ZERO - Static variable in class io.github.bucket4j.distributed.remote.CommandResult
 
A B C D E F G H I L M N O P R S T U V W Z 
Skip navigation links

Copyright © 2020. All rights reserved.