A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes All Packages

A

AbstractCacheBase<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Abstract base class for all cache implementations providing common functionality.
AbstractCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Constructor for all cache implementations.
accessBuffer - Variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 
AccessBuffer<K> - Class in io.github.dhruv1110.jcachex.concurrent
A lock-free access buffer that records cache operations using ring buffers and write-ahead logging for high-performance concurrent access.
AccessBuffer(int, long) - Constructor for class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Creates a new access buffer.
AccessBuffer.AccessRecord<K> - Class in io.github.dhruv1110.jcachex.concurrent
Represents a cache access operation.
AccessBuffer.AccessType - Enum in io.github.dhruv1110.jcachex.concurrent
 
AccessPattern(long, long, double, boolean) - Constructor for class io.github.dhruv1110.jcachex.warming.WarmingContext.AccessPattern
 
AccessRecord(K, AccessBuffer.AccessType, long, int) - Constructor for class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
 
ACTIVE - io.github.dhruv1110.jcachex.impl.OptimizedCacheBase.State
 
adaptive() - Static method in class io.github.dhruv1110.jcachex.CacheFactory
Creates an adaptive cache builder that can switch between local and distributed based on environment or runtime conditions.
AdaptiveCacheBuilder() - Constructor for class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
addListener(CacheEventListener<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Adds an event listener to receive notifications about cache operations.
addNode(String) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Adds a new node to the cluster.
addNode(String) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
afterClear() - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Called after clearing the data map.
ALLOCATION_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
AllocationOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Allocation-optimized cache implementation that minimizes object allocation overhead.
AllocationOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.AllocationOptimizedCache
 
asyncLoader(Function<K, CompletableFuture<V>>) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the async loader function for automatic value loading.
asyncLoader(Function<K, CompletableFuture<V>>) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the function used to load values asynchronously when not present in cache.
averageLoadTime() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the average time spent loading a value, in nanoseconds.
AVRO - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.SerializationType
 

B

backoffMultiplier(double) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Sets the backoff multiplier for exponential backoff.
BASIC - io.github.dhruv1110.jcachex.FrequencySketchType
Basic frequency sketch using CountMinSketch with standard parameters.
beforeClear() - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Called before clearing the data map.
broadcast(Collection<String>, NetworkProtocol.CacheOperation) - Method in class io.github.dhruv1110.jcachex.distributed.DefaultNetworkProtocol
 
broadcast(Collection<String>, NetworkProtocol.CacheOperation) - Method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Broadcasts a cache operation to multiple nodes.
bufferSize(int) - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
build() - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Builds and returns the configured cache instance.
build() - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Builds and returns a new CacheConfig instance with the configured settings.
build() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
build() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
build() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
build() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Builder
 
build() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.Builder
 
build() - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Builds the retry policy.
build() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
builder() - Static method in class io.github.dhruv1110.jcachex.CacheConfig
Creates a new builder instance for constructing cache configurations.
builder() - Static method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Creates a new distributed cache builder.
builder() - Static method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Creates a new metrics registry builder.
builder() - Static method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Creates a new circuit breaker builder.
builder() - Static method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy
Creates a new retry policy builder.
builder() - Static method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Creates a new builder for WarmingResult.
Builder() - Constructor for class io.github.dhruv1110.jcachex.CacheConfig.Builder
 
Builder() - Constructor for class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
Builder() - Constructor for class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Builder
 
Builder() - Constructor for class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.Builder
 
Builder() - Constructor for class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
 
Builder() - Constructor for class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
bulkLoad(Map<K, V>) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
Bulk load data for optimal read performance.

C

Cache<K,​V> - Interface in io.github.dhruv1110.jcachex
A thread-safe cache that provides a unified API for both Kotlin and Java applications.
CacheBuilder<K,​V> - Class in io.github.dhruv1110.jcachex
Fluent builder for creating JCacheX cache instances with enhanced type support.
CacheBuilder.CacheType - Enum in io.github.dhruv1110.jcachex
Enumeration of available cache types.
cacheConfig(CacheConfig<K, V>) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
CacheConfig<K,​V> - Class in io.github.dhruv1110.jcachex
Configuration options for a JCacheX cache instance.
CacheConfig.Builder<K,​V> - Class in io.github.dhruv1110.jcachex
Builder class for constructing CacheConfig instances.
CacheConfigurationException - Exception in io.github.dhruv1110.jcachex.exceptions
Exception thrown when there are configuration errors in cache setup.
CacheConfigurationException(String) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheConfigurationException
Constructs a new cache configuration exception with the specified detail message.
CacheConfigurationException(String, String) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheConfigurationException
Constructs a new cache configuration exception with a specific error code.
CacheConfigurationException(String, Throwable) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheConfigurationException
Constructs a new cache configuration exception with the specified detail message and cause.
CacheEntry<V> - Class in io.github.dhruv1110.jcachex
Represents a cache entry containing a value along with metadata for cache management.
CacheEntry(V, long, Instant) - Constructor for class io.github.dhruv1110.jcachex.CacheEntry
 
CacheEventListener<K,​V> - Interface in io.github.dhruv1110.jcachex
Interface for cache event listeners.
CacheException - Exception in io.github.dhruv1110.jcachex.exceptions
Base exception class for all JCacheX-related exceptions.
CacheException(String) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheException
Constructs a new cache exception with the specified detail message.
CacheException(String, CacheException.ErrorType, String, boolean) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheException
Constructs a new cache exception with the specified detail message, error type, and error code.
CacheException(String, Throwable) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheException
Constructs a new cache exception with the specified detail message and cause.
CacheException(String, Throwable, CacheException.ErrorType, String, boolean) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheException
Constructs a new cache exception with the specified detail message, cause, error type, and error code.
CacheException.ErrorType - Enum in io.github.dhruv1110.jcachex.exceptions
Error classification for handling different types of cache errors.
CacheFactory - Class in io.github.dhruv1110.jcachex
Unified factory for creating both local and distributed caches.
CacheFactory() - Constructor for class io.github.dhruv1110.jcachex.CacheFactory
 
CacheFactory.AdaptiveCacheBuilder<K,​V> - Class in io.github.dhruv1110.jcachex
Builder for adaptive caches that can switch between local and distributed based on environment conditions.
CacheFactory.DistributedCacheBuilder<K,​V> - Class in io.github.dhruv1110.jcachex
Builder for distributed caches with all advanced features.
CacheFactory.LocalCacheBuilder<K,​V> - Class in io.github.dhruv1110.jcachex
Builder for local caches with production-ready features.
CacheLocalityOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Cache implementation optimized for memory access patterns and cache locality.
CacheLocalityOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
CacheOperation(String, String) - Constructor for class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CacheOperation
 
CacheOperationException - Exception in io.github.dhruv1110.jcachex.exceptions
Exception thrown when cache operations fail at runtime.
CacheOperationException(String) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Constructs a new cache operation exception with the specified detail message.
CacheOperationException(String, String, boolean) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Constructs a new cache operation exception with specific error code and retryable flag.
CacheOperationException(String, Throwable) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Constructs a new cache operation exception with the specified detail message and cause.
CacheOperationException(String, Throwable, String, boolean) - Constructor for exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Constructs a new cache operation exception with cause, error code and retryable flag.
CacheStats - Class in io.github.dhruv1110.jcachex
Statistics for cache performance monitoring and analysis.
CacheStats() - Constructor for class io.github.dhruv1110.jcachex.CacheStats
 
CacheStats(AtomicLong, AtomicLong, AtomicLong, AtomicLong, AtomicLong, AtomicLong) - Constructor for class io.github.dhruv1110.jcachex.CacheStats
 
cacheType(CacheBuilder.CacheType) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the cache type to use.
CacheWarmingStrategy<K,​V> - Interface in io.github.dhruv1110.jcachex.warming
Interface for cache warming strategies.
CacheWarmingStrategy.WarmingPriority - Enum in io.github.dhruv1110.jcachex.warming
Warming priority levels.
calculateAverageLoadTime(long, long) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Calculates the average load time.
calculateHitRatio(long, long) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Calculates the hit ratio from hit and miss counts.
calculateMissRatio(long, long) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Calculates the miss ratio from hit and miss counts.
calculateOptimalCapacity(long) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Calculates the optimal initial capacity for a ConcurrentHashMap based on the maximum size and load factor.
calculateOptimalConcurrency() - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Calculates the optimal concurrency level for concurrent data structures.
CAPACITY - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
Resource capacity errors
checkAlerts() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Checks all registered alerts.
circuitBreaker(CircuitBreaker) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
circuitBreaker(CircuitBreaker) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
CircuitBreaker - Class in io.github.dhruv1110.jcachex.resilience
Circuit breaker implementation for cache operations.
CircuitBreaker.Builder - Class in io.github.dhruv1110.jcachex.resilience
Builder for CircuitBreaker.
CircuitBreaker.CircuitBreakerException - Exception in io.github.dhruv1110.jcachex.resilience
Exception thrown when circuit breaker is open.
CircuitBreaker.CircuitBreakerMetrics - Class in io.github.dhruv1110.jcachex.resilience
Circuit breaker metrics container.
CircuitBreaker.State - Enum in io.github.dhruv1110.jcachex.resilience
Circuit breaker states.
CircuitBreakerException(String) - Constructor for exception io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerException
 
CircuitBreakerMetrics(CircuitBreaker.State, int, int, long, long, long, double) - Constructor for class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerMetrics
 
cleanupExpiredEntries() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Clean up expired entries.
clear() - Method in interface io.github.dhruv1110.jcachex.Cache
Removes all mappings from this cache.
clear() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Clears all pending accesses.
clear() - Method in class io.github.dhruv1110.jcachex.concurrent.RingBuffer
Clears all elements from the buffer.
clear() - Method in class io.github.dhruv1110.jcachex.concurrent.StripedRingBuffer
Clears all buffers.
clear() - Method in class io.github.dhruv1110.jcachex.eviction.CompositeEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLFUEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLRUEvictionStrategy
 
clear() - Method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
Clears all state maintained by the strategy.
clear() - Method in class io.github.dhruv1110.jcachex.eviction.FIFOEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.eviction.FILOEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.eviction.LFUEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.eviction.LRUEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.eviction.SegmentedLRU
Clears all entries from the segmented LRU.
clear() - Method in class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
 
clear() - Method in class io.github.dhruv1110.jcachex.FrequencySketch
Clears all frequency data.
clear() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Template method for clear operation with statistics recording.
clear() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
clear() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
clear() - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
clear() - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
clear() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
clear() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
clear() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
clear() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
clear() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
CLEAR - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
 
clearAsync() - Method in interface io.github.dhruv1110.jcachex.Cache
Asynchronously removes all mappings from this cache.
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
CLEARED - io.github.dhruv1110.jcachex.EvictionReason
The entry was evicted because the cache was cleared.
clearGlobally() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Clears all entries across all nodes in the cluster.
clearGlobally() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
close() - Method in class io.github.dhruv1110.jcachex.impl.DefaultCache
Closes this cache and releases any resources associated with it.
close() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Manually closes the circuit breaker.
CLOSED - io.github.dhruv1110.jcachex.resilience.CircuitBreaker.State
 
clusterName(String) - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
clusterName(String) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
clusterName(String) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
clusterName(String) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
ClusterTopology(String, Set<DistributedCache.NodeInfo>, int, long) - Constructor for class io.github.dhruv1110.jcachex.distributed.DistributedCache.ClusterTopology
 
CompositeEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Composite eviction strategy that combines multiple strategies.
CompositeEvictionStrategy(List<EvictionStrategy<K, V>>) - Constructor for class io.github.dhruv1110.jcachex.eviction.CompositeEvictionStrategy
 
compression(NetworkProtocol.CompressionType) - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
compressionEnabled(boolean) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
compressionEnabled(boolean) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
concurrencyLevel(int) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the concurrency level hint for the cache's internal data structure.
concurrencyLevel(int) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the concurrency level for the cache's internal data structure.
ConcurrentCacheBase<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Base class for concurrent cache implementations providing thread-safety primitives.
ConcurrentCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Constructor for concurrent cache implementations.
concurrentModification(Object) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Creates an operation exception for concurrent modification conflicts.
config - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
config() - Method in interface io.github.dhruv1110.jcachex.Cache
Returns the cache configuration.
config() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Common implementation of config() method.
config() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
config() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
config() - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
config() - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
config() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
config() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
config() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
config() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
config() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
CONFIGURATION - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
Configuration or setup errors
ConfigurationProvider - Class in io.github.dhruv1110.jcachex.impl
Utility class for common configuration handling patterns.
conflictingSettings(String, String) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheConfigurationException
Creates a configuration exception for conflicting settings.
connectionTimeout(long) - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
consistencyLevel(DistributedCache.ConsistencyLevel) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
consistencyLevel(DistributedCache.ConsistencyLevel) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
consistencyLevel(DistributedCache.ConsistencyLevel) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
containsKey(K) - Method in interface io.github.dhruv1110.jcachex.Cache
Returns true if this cache contains a mapping for the specified key.
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Common implementation of containsKey with validation.
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
count() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Counter
 
count() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Histogram
 
count() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Timer
 
counter(String) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Returns a counter metric.
Counter() - Constructor for class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Counter
 
create() - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
create() - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
create() - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
createBasicConfig(long, boolean) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Creates a basic configuration object with minimal settings.
createBasicStats(AtomicLong, AtomicLong) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Creates a basic CacheStats object from hit and miss counters.
createCacheEntry(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Creates a cache entry with proper weight calculation.
createCacheEntry(V) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Creates a cache entry with proper timestamp and expiration settings.
createCacheEntry(V) - Method in class io.github.dhruv1110.jcachex.impl.AllocationOptimizedCache
Override to use pooled entry creation for allocation optimization.
createCacheEntry(V) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Creates a cache entry with proper weight calculation.
createComprehensiveStats(AtomicLong, AtomicLong, AtomicLong, AtomicLong, AtomicLong) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Creates a comprehensive CacheStats object with all counters.
createMapEntry(K, V) - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Create a Map.Entry for the entries() collection view.
createSizeWeightConfig(long, long, boolean) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Creates a configuration object with size and weight limits.
CRITICAL - io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy.WarmingPriority
 
currentSize - Variable in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
currentWeight - Variable in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 

D

data - Variable in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
 
DataBackedCacheBase<K,​V,​E> - Class in io.github.dhruv1110.jcachex.impl
Abstract base class for cache implementations that store data in a ConcurrentHashMap.
DataBackedCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Constructor for data-backed cache implementations.
DEFAULT - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
DEFAULT_DRAIN_INTERVAL_NANOS - Static variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 
DEFAULT_DRAIN_THRESHOLD - Static variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 
DefaultCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Default implementation of the Cache interface.
DefaultCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.DefaultCache
Creates a new DefaultCache with the specified configuration.
DefaultDistributedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Default implementation of DistributedCache interface.
DefaultDistributedCache.Builder<K,​V> - Class in io.github.dhruv1110.jcachex.impl
 
DefaultNetworkProtocol - Class in io.github.dhruv1110.jcachex.distributed
Default implementation of NetworkProtocol.
DefaultNetworkProtocol(NetworkProtocol.ProtocolBuilder) - Constructor for class io.github.dhruv1110.jcachex.distributed.DefaultNetworkProtocol
 
defaultPolicy() - Static method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy
Creates a default retry policy with reasonable defaults.
DEGRADED - io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
 
delayFunction(Function<Integer, Duration>) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Sets a custom delay function.
directory(String) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the directory path for persistent cache storage.
distributed() - Static method in class io.github.dhruv1110.jcachex.CacheFactory
Creates a distributed cache builder.
DistributedCache<K,​V> - Interface in io.github.dhruv1110.jcachex.distributed
Distributed cache interface that extends the base Cache interface with multi-node capabilities.
DistributedCache.Builder<K,​V> - Interface in io.github.dhruv1110.jcachex.distributed
Builder interface for creating distributed caches.
DistributedCache.ClusterTopology - Class in io.github.dhruv1110.jcachex.distributed
Cluster topology information.
DistributedCache.ConsistencyLevel - Enum in io.github.dhruv1110.jcachex.distributed
Consistency levels for distributed operations.
DistributedCache.DistributedMetrics - Class in io.github.dhruv1110.jcachex.distributed
Metrics specific to distributed cache operations.
DistributedCache.NodeInfo - Class in io.github.dhruv1110.jcachex.distributed
Information about a cluster node.
DistributedCache.NodeStatus - Enum in io.github.dhruv1110.jcachex.distributed
Node health status.
DistributedCacheBuilder() - Constructor for class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
DistributedMetrics(long, long, double, long, long, Map<String, Long>) - Constructor for class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
 
distributedWhen(Function<Map<String, String>, Boolean>) - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
doClear() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Implementation-specific clear operation.
doClear() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
doClear() - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Common clear implementation.
doClear() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Enhanced clear operation with versioning.
doContainsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Implementation-specific containsKey operation.
doContainsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
doContainsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Common implementation of containsKey with entry validation.
doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Implementation-specific get operation.
doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.JITOptimizedCache
Override to use JIT-optimized read path.
doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Optimized get operation with lock-free reads where possible.
doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Implementation-specific put operation.
doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.JITOptimizedCache
Override to use JIT-optimized write path.
doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Optimized put operation with batched processing.
doRemove(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Implementation-specific remove operation.
doRemove(K) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
doRemove(K) - Method in class io.github.dhruv1110.jcachex.impl.JITOptimizedCache
Override to use JIT-optimized remove path.
drain(Consumer<E>) - Method in class io.github.dhruv1110.jcachex.concurrent.RingBuffer
Drains elements from the buffer and processes them.
drainAccessBuffer() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Drains the access buffer and updates eviction state.
drainAll(Consumer<E>) - Method in class io.github.dhruv1110.jcachex.concurrent.StripedRingBuffer
Drains all buffers and processes the elements.
drainToHandler(Consumer<AccessBuffer.AccessRecord<K>>) - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Drains the access buffer and processes all recorded accesses.
duration(Duration) - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 

E

empty() - Static method in class io.github.dhruv1110.jcachex.CacheStats
 
enableAutoDiscovery(boolean) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
enableAutoDiscovery(boolean) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
enableObservability(boolean) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
enableObservability(boolean) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
enableReadOnlyMode() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
Enable read-only mode for maximum read performance.
enableReadRepair(boolean) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
enableReadRepair(boolean) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
enableResilience(boolean) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
enableResilience(boolean) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
enableStats(boolean) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
enableStats(boolean) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
enableWarming(boolean) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
enableWarming(boolean) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
encryption(boolean) - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
encryptionEnabled(boolean) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
encryptionEnabled(boolean) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
endTime(Instant) - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
enforceSize() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Hook for subclasses to perform size enforcement.
enforceSize() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Override size enforcement to use eviction strategy.
enforceSize() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Optimized size enforcement using advanced eviction strategies.
ENHANCED_LFU() - Static method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
Enhanced LFU eviction strategy with frequency sketch.
ENHANCED_LRU() - Static method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
Enhanced LRU eviction strategy with frequency sketch.
EnhancedLFUEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Enhanced LFU eviction strategy with frequency sketch support and O(1) operations.
EnhancedLFUEvictionStrategy() - Constructor for class io.github.dhruv1110.jcachex.eviction.EnhancedLFUEvictionStrategy
Creates an enhanced LFU eviction strategy with default frequency sketch.
EnhancedLFUEvictionStrategy(FrequencySketchType, long) - Constructor for class io.github.dhruv1110.jcachex.eviction.EnhancedLFUEvictionStrategy
Creates an enhanced LFU eviction strategy with specified frequency sketch type.
EnhancedLRUEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Enhanced LRU eviction strategy with frequency sketch support.
EnhancedLRUEvictionStrategy() - Constructor for class io.github.dhruv1110.jcachex.eviction.EnhancedLRUEvictionStrategy
Creates an enhanced LRU eviction strategy with default frequency sketch.
EnhancedLRUEvictionStrategy(FrequencySketchType, long) - Constructor for class io.github.dhruv1110.jcachex.eviction.EnhancedLRUEvictionStrategy
Creates an enhanced LRU eviction strategy with specified frequency sketch type.
ensureCapacity(int) - Method in class io.github.dhruv1110.jcachex.FrequencySketch
Ensures the frequency sketch can handle at least the specified capacity.
entries() - Method in interface io.github.dhruv1110.jcachex.Cache
Returns a view of all the key-value pairs in this cache.
entries() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
entries() - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Common implementation of entries() method with filtering.
entries() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
entries() - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
entries() - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
entries() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
entries() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
entries() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
entries() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
entries() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
equals(Object) - Method in class io.github.dhruv1110.jcachex.CacheStats
 
EVENTUAL - io.github.dhruv1110.jcachex.distributed.DistributedCache.ConsistencyLevel
Eventual consistency - operation completes locally, replicates asynchronously.
EVICT - io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessType
 
evictEntries() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
evictEntries(K) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Evict entries based on the eviction strategy, avoiding a specific key.
evictionCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the number of entries that have been evicted from the cache.
evictionFailure(Throwable) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Creates an operation exception for eviction failures.
EvictionReason - Enum in io.github.dhruv1110.jcachex
Reasons for cache eviction.
evictionStrategy - Variable in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
evictionStrategy(EvictionStrategy<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the eviction strategy to use.
evictionStrategy(EvictionStrategy<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the eviction strategy used to determine which entries to remove when the cache size or weight limits are exceeded.
EvictionStrategy<K,​V> - Interface in io.github.dhruv1110.jcachex.eviction
Interface for cache eviction strategies.
execute(Runnable) - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Executes the given runnable with circuit breaker protection.
execute(Runnable) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy
Executes the given runnable with retry logic.
execute(Supplier<T>) - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Executes the given supplier with circuit breaker protection.
execute(Supplier<T>) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy
Executes the given supplier with retry logic.
expireAfterAccess(long, TimeUnit) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the duration after which an entry should expire after being accessed.
expireAfterAccess(long, TimeUnit) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the duration after which an entry should be automatically removed from the cache once the duration has elapsed after the entry's creation, last update, or last access.
expireAfterAccess(Duration) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the duration after which an entry should expire after being accessed.
expireAfterAccess(Duration) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the duration after which an entry should be automatically removed from the cache once the duration has elapsed after the entry's creation, last update, or last access.
expireAfterAccess(Duration) - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
expireAfterAccess(Duration) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
expireAfterAccess(Duration) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
expireAfterWrite(long, TimeUnit) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the duration after which an entry should expire after being written.
expireAfterWrite(long, TimeUnit) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the duration after which an entry should be automatically removed from the cache once the duration has elapsed after the entry's creation or last update.
expireAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the duration after which an entry should expire after being written.
expireAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the duration after which an entry should be automatically removed from the cache once the duration has elapsed after the entry's creation or last update.
expireAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
expireAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
expireAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
EXPIRED - io.github.dhruv1110.jcachex.EvictionReason
The entry was evicted because it expired.
EXPLICIT - io.github.dhruv1110.jcachex.EvictionReason
The entry was evicted because it was explicitly removed.
extractValue(E) - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Extract the value from an entry.
extractValue(CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 

F

FAILED - io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
 
failure(String, String) - Static method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationResponse
 
failure(String, Duration) - Static method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Creates a failed warming result.
failureCount(int) - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
failureReason(String) - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
failureThreshold(int) - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.Builder
 
FIFO() - Static method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
FIFO eviction strategy.
FIFOEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Optimized First In, First Out (FIFO) eviction strategy with O(1) operations.
FIFOEvictionStrategy() - Constructor for class io.github.dhruv1110.jcachex.eviction.FIFOEvictionStrategy
 
FILO() - Static method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
FILO eviction strategy.
FILOEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Optimized First In, Last Out (FILO) eviction strategy with O(1) operations.
FILOEvictionStrategy() - Constructor for class io.github.dhruv1110.jcachex.eviction.FILOEvictionStrategy
 
flushWrites() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
Flush all pending writes to main storage.
forceDrain(Consumer<AccessBuffer.AccessRecord<K>>) - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Forces an immediate drain of all pending accesses.
forDevelopment() - Static method in class io.github.dhruv1110.jcachex.CacheBuilder
Creates a builder pre-configured for development and testing.
forHighPerformance() - Static method in class io.github.dhruv1110.jcachex.CacheBuilder
Creates a builder pre-configured for high-performance scenarios.
forMachineLearning() - Static method in class io.github.dhruv1110.jcachex.CacheBuilder
Creates a builder pre-configured for machine learning workloads.
formatDetailedMetrics(long, long, long, long, long, long) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Creates a detailed performance metrics string.
formatStatsSummary(long, long, long, long) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Creates a formatted statistics summary string.
forMemoryConstrainedEnvironment() - Static method in class io.github.dhruv1110.jcachex.CacheBuilder
Creates a builder pre-configured for memory-constrained environments.
forReadHeavyWorkload() - Static method in class io.github.dhruv1110.jcachex.CacheBuilder
Creates a builder pre-configured for high-performance read workloads.
forWriteHeavyWorkload() - Static method in class io.github.dhruv1110.jcachex.CacheBuilder
Creates a builder pre-configured for high-performance write workloads.
frequency - Variable in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
 
frequency(E) - Method in class io.github.dhruv1110.jcachex.FrequencySketch
Returns the estimated frequency of the specified element.
frequency(K) - Method in class io.github.dhruv1110.jcachex.OptimizedFrequencySketch
Get the frequency estimate for a key.
FREQUENCY_SKETCH_SIZE - Static variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 
frequencySketch - Variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 
FrequencySketch<E> - Class in io.github.dhruv1110.jcachex
A probabilistic frequency sketch based on CountMinSketch for efficient frequency tracking with minimal memory overhead.
FrequencySketch(long) - Constructor for class io.github.dhruv1110.jcachex.FrequencySketch
Creates a new frequency sketch with the specified maximum size.
frequencySketchType(FrequencySketchType) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the frequency sketch type for tracking access patterns.
frequencySketchType(FrequencySketchType) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the frequency sketch type to use for tracking access patterns.
FrequencySketchType - Enum in io.github.dhruv1110.jcachex
Enumeration of frequency sketch types available for eviction strategies.

G

Gauge(Supplier<Double>) - Constructor for class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Gauge
 
get(K) - Method in interface io.github.dhruv1110.jcachex.Cache
Returns the value associated with the key in this cache, or null if there is no cached value for the key.
get(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Template method for get operation with common validation and statistics.
get(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
get(K) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
get(K) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
get(K) - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
get(K) - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
get(K) - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
get(K) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
get(K) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
get(K) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
GET - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
 
getAccessCount() - Method in class io.github.dhruv1110.jcachex.CacheEntry
 
getAccessCount() - Method in class io.github.dhruv1110.jcachex.warming.WarmingContext.AccessPattern
 
getAccessFrequency() - Method in class io.github.dhruv1110.jcachex.warming.WarmingContext.AccessPattern
 
getAccessPatterns() - Method in interface io.github.dhruv1110.jcachex.warming.WarmingContext
Returns access patterns for cache keys.
getAddress() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
 
getAll(K[]) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
SIMD-optimized bulk get operation
getAllocationMetrics() - Method in class io.github.dhruv1110.jcachex.impl.AllocationOptimizedCache
Returns allocation-specific performance metrics.
getAsync(K) - Method in interface io.github.dhruv1110.jcachex.Cache
Asynchronously returns the value associated with the key in this cache.
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
getAsyncLoader() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the function used to load values asynchronously when not present in cache.
getAverageLatency() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.NetworkStats
 
getAverageNetworkLatency() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
 
getBytesReceived() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.NetworkStats
 
getBytesTransmitted() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.NetworkStats
 
getCache() - Method in interface io.github.dhruv1110.jcachex.warming.WarmingContext
Returns the cache to be warmed.
getCacheStats(String) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Returns cache statistics for a registered cache.
getCapacity() - Method in class io.github.dhruv1110.jcachex.FrequencySketch
Returns the current capacity of the frequency sketch.
getClusterName() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.ClusterTopology
 
getClusterTopology() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Returns the current cluster topology.
getClusterTopology() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
getConcurrencyLevel() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the concurrency level for the cache's internal data structure.
getConflictResolutions() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
 
getConnectionFailures() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.NetworkStats
 
getConsistencyLevel() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Returns the consistency level used by this cache.
getConsistencyLevel() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.GetOperation
 
getConsistencyLevel() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.PutOperation
 
getConsistencyLevel() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
getContentionLevel() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Returns the current contention level.
getContentionLevel() - Method in class io.github.dhruv1110.jcachex.concurrent.StripedRingBuffer
Returns the current contention level.
getCreationTime() - Method in class io.github.dhruv1110.jcachex.CacheEntry
Get creation time as Instant (created lazily for compatibility)
getCreationTimeNanos() - Method in class io.github.dhruv1110.jcachex.CacheEntry
 
getCurrentStats() - Method in interface io.github.dhruv1110.jcachex.warming.WarmingContext
Returns the current cache statistics.
getCurrentWeight() - Method in class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
Returns the current total weight of all entries.
getCurrentWeight() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Calculates the current total weight of entries in the cache.
getCurrentWeight() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
getDataMap() - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Get direct access to the underlying data map.
getDetailedMetrics() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCache
Returns detailed performance metrics for the optimized cache.
getDirectory() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the directory path for persistent cache storage.
getDistributedMetrics() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Returns detailed metrics about distributed operations.
getDistributedMetrics() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
getDrainStatus() - Method in class io.github.dhruv1110.jcachex.concurrent.RingBuffer
Gets the current drain status.
getDuration() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Returns the total duration of the warming operation.
getEndTime() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Returns the end time of the warming operation.
getErrorCode() - Method in exception io.github.dhruv1110.jcachex.exceptions.CacheException
Returns the specific error code, if available.
getErrorMessage() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationResponse
 
getErrorType() - Method in exception io.github.dhruv1110.jcachex.exceptions.CacheException
Returns the error type classification.
getEvictionCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
getEvictionStrategy() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the eviction strategy used to determine which entries to remove when the cache size or weight limits are exceeded.
getExpirationTime() - Method in class io.github.dhruv1110.jcachex.CacheEntry
Get expiration time as Instant (returns original Instant for compatibility)
getExpireAfterAccess() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the duration after which an entry should be automatically removed from the cache once the duration has elapsed after the entry's creation, last update, or last access.
getExpireAfterWrite() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the duration after which an entry should be automatically removed from the cache once the duration has elapsed after the entry's creation or last update.
getFailureCount() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerMetrics
 
getFailureCount() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Returns the current failure count.
getFailureCount() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Returns the number of failed warming attempts.
getFailureRate() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerMetrics
 
getFailureRate() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Returns the failure rate as a percentage.
getFailureReason() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Returns the failure reason if warming failed.
getFrequencySketch() - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
Returns the frequency sketch for testing purposes.
getFrequencySketchType() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the frequency sketch type used for tracking access patterns.
getFrequentlyAccessedKeys() - Method in interface io.github.dhruv1110.jcachex.warming.WarmingContext
Returns keys that are frequently accessed.
getHealthyNodeCount() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.ClusterTopology
 
getHitCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
getHitRate() - Method in class io.github.dhruv1110.jcachex.CacheStats
Compatibility method for getHitRate() - alias for hitRate().
getIdleTime(K) - Method in class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
Returns the idle time for a specific key.
getInitialCapacity() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the initial capacity of the cache's internal data structure.
getJITMetrics() - Method in class io.github.dhruv1110.jcachex.impl.JITOptimizedCache
Returns JIT-specific performance metrics.
getKey() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.GetOperation
 
getKey() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.PutOperation
 
getKeys() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.InvalidateOperation
 
getLastAccessTime() - Method in class io.github.dhruv1110.jcachex.CacheEntry
Get last access time as Instant (created lazily for compatibility)
getLastAccessTime() - Method in class io.github.dhruv1110.jcachex.warming.WarmingContext.AccessPattern
 
getLastAccessTime(K) - Method in class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
Returns the last access time for a specific key.
getLastAccessTimeNanos() - Method in class io.github.dhruv1110.jcachex.CacheEntry
 
getLastAnalysis() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache.ProfileData
 
getLastBottleneckReport() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache.ProfileData
 
getLastSeen() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
 
getLevel() - Method in enum io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy.WarmingPriority
 
getListeners() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns a copy of the set of event listeners registered for this cache.
getLoadCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
getLoader() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the function used to load values synchronously when not present in cache.
getLoadFailureCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
getMainSize() - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
Returns current main space size.
getMaxIdleTime() - Method in class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
Returns the maximum idle time threshold.
getMaximumSize() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the maximum number of entries the cache may contain.
getMaximumWeight() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the maximum total weight of entries the cache may contain.
getMaxWeight() - Method in class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
Returns the maximum weight limit.
getMessagesReceived() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.NetworkStats
 
getMessagesSent() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.NetworkStats
 
getMetrics() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Returns comprehensive circuit breaker metrics.
getMissCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
getMissRate() - Method in class io.github.dhruv1110.jcachex.CacheStats
Compatibility method for getMissRate() - alias for missRate().
getNetworkFailures() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
 
getNetworkRequests() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
 
getNetworkStats() - Method in class io.github.dhruv1110.jcachex.distributed.DefaultNetworkProtocol
 
getNetworkStats() - Method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Returns network statistics.
getNetworkSuccessRate() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
 
getNodeId() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
 
getNodes() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.ClusterTopology
 
getNodeStatuses() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Returns the status of each node in the cluster.
getNodeStatuses() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
GetOperation(String, String, Object, DistributedCache.ConsistencyLevel) - Constructor for class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.GetOperation
 
getOperationId() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CacheOperation
 
getOperationId() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationResponse
 
getOperationState() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Returns the current operation state.
getOptimizationCount() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache.ProfileData
 
getPartitionCount() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.ClusterTopology
 
getPartitions() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
 
getPendingAccessCount() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Returns the current number of pending accesses.
getPendingWriteCount() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
Get pending write count.
getPerformanceMetrics() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Returns performance metrics for monitoring.
getPerNodeLatencies() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
 
getPerNodeStats() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Returns cache statistics for each node in the cluster.
getPerNodeStats() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
getProfileData() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
getReadLock(K) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Get read lock for a specific key.
getRefreshAfterWrite() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the duration after which an entry should be automatically refreshed once the duration has elapsed after the entry's creation or last update.
getReplicationFactor() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Returns the replication factor for this cache.
getReplicationFactor() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
getReplicationLag() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
 
getResult() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationResponse
 
getSafeInitialCapacity(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Gets a safe initial capacity value, handling null cases.
getSafeMaximumSize(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Gets a safe maximum size value, handling null cases.
getSketchStats() - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLFUEvictionStrategy
Returns statistics about the frequency sketch.
getSketchStats() - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLRUEvictionStrategy
Returns statistics about the frequency sketch.
getSketchType() - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLFUEvictionStrategy
Returns the frequency sketch type being used.
getSketchType() - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLRUEvictionStrategy
Returns the frequency sketch type being used.
getSourceNodeId() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CacheOperation
 
getStartTime() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Returns the start time of the warming operation.
getState() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerMetrics
 
getState() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Returns the current state of the circuit breaker.
getStats() - Method in class io.github.dhruv1110.jcachex.eviction.SegmentedLRU
Returns performance statistics.
getStats() - Method in class io.github.dhruv1110.jcachex.OptimizedFrequencySketch
Get statistics about the sketch.
getStatus() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
 
getStripeCount() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Returns the number of stripes in the ring buffer.
getStripeCount() - Method in class io.github.dhruv1110.jcachex.concurrent.StripedRingBuffer
Returns the current number of stripes.
getStripeIndex(K) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Get the stripe index for a key to enable striped locking.
getSuccessCount() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerMetrics
 
getSuccessCount() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Returns the current success count (used in half-open state).
getSuccessCount() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Returns the number of successfully warmed entries.
getThroughput() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.NetworkStats
 
getTimestamp() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CacheOperation
 
getTimestamp() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationResponse
 
getTotalFailures() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerMetrics
 
getTotalLoadTime() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
getTotalRequests() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerMetrics
 
getTotalSuccesses() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.CircuitBreakerMetrics
 
getType() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CacheOperation
 
getType() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.GetOperation
 
getType() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.InvalidateOperation
 
getType() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.PutOperation
 
getValue() - Method in class io.github.dhruv1110.jcachex.CacheEntry
 
getValue() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.PutOperation
 
getVersion() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.ClusterTopology
 
getVersion() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Returns the current version for optimistic concurrency control.
getWarmingPriority(K) - Method in interface io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy
Returns the priority for warming a specific key.
getWarnings() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Returns any warnings generated during warming.
getWeigher() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns the weigher function used to calculate entry weights.
getWeight() - Method in class io.github.dhruv1110.jcachex.CacheEntry
 
getWeight(K) - Method in class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
Returns the weight of a specific key.
getWindowSize() - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
Returns current window size.
getWithConsistency(K, DistributedCache.ConsistencyLevel) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Gets a value from the cache with the specified consistency level.
getWithConsistency(K, DistributedCache.ConsistencyLevel) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
getWriteCount() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
Get write statistics.
getWriteLock(K) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Get write lock for a specific key.
gossipInterval(Duration) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
gossipInterval(Duration) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
GZIP - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CompressionType
 

H

HALF_OPEN - io.github.dhruv1110.jcachex.resilience.CircuitBreaker.State
 
handle(NetworkProtocol.CacheOperation) - Method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationHandler
 
HARDWARE_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
HardwareOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Hardware-optimized cache implementation that leverages CPU-specific features.
HardwareOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
hasExpiration - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
hasExpiration(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Checks if the configuration has expiration settings.
hashCode() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
hasLoader(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Checks if the configuration has loading capability.
hasMaximumSize - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
hasMaximumWeight - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
hasRefresh(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Checks if the configuration has refresh settings.
HEALTHY - io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
 
HEARTBEAT - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
 
HIGH - io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy.WarmingPriority
 
histogram(String) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Returns a histogram metric.
Histogram() - Constructor for class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Histogram
 
hitCount - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
hitCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the number of successful cache lookups.
hitRate() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the ratio of successful cache lookups to total requests.
http() - Static method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Creates an HTTP protocol builder.
HTTP - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolType
 

I

IDLE - io.github.dhruv1110.jcachex.concurrent.RingBuffer.DrainStatus
 
IdleTimeEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Optimized Idle Time-based eviction strategy.
IdleTimeEvictionStrategy(Duration) - Constructor for class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
 
increment() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Counter
 
increment(long) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Counter
 
increment(E) - Method in class io.github.dhruv1110.jcachex.FrequencySketch
Records an access to the specified element.
increment(K) - Method in class io.github.dhruv1110.jcachex.OptimizedFrequencySketch
Increment the frequency counter for a key with minimal allocation.
incrementAccessCount() - Method in class io.github.dhruv1110.jcachex.CacheEntry
Optimized access count increment with minimal overhead
initialCapacity(int) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the initial capacity hint for the cache's internal data structure.
initialCapacity(int) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the initial capacity of the cache's internal data structure.
initialDelay(Duration) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Sets the initial delay between retries.
INVALIDATE - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
 
invalidateGlobally(Collection<K>) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Invalidates multiple keys across all nodes in the cluster.
invalidateGlobally(Collection<K>) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
invalidateGlobally(K) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Invalidates a key across all nodes in the cluster.
invalidateGlobally(K) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
InvalidateOperation(String, String, Collection<Object>) - Constructor for class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.InvalidateOperation
 
invalidCacheState(String) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Creates an operation exception for cache state errors.
invalidKey(Object) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Creates an operation exception for key validation failures.
invalidMaximumSize(long) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheConfigurationException
Creates a configuration exception for invalid maximum size.
invalidMaximumWeight(long) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheConfigurationException
Creates a configuration exception for invalid maximum weight.
invalidValue(Object) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Creates an operation exception for value validation failures.
io.github.dhruv1110.jcachex - package io.github.dhruv1110.jcachex
 
io.github.dhruv1110.jcachex.concurrent - package io.github.dhruv1110.jcachex.concurrent
 
io.github.dhruv1110.jcachex.distributed - package io.github.dhruv1110.jcachex.distributed
 
io.github.dhruv1110.jcachex.eviction - package io.github.dhruv1110.jcachex.eviction
 
io.github.dhruv1110.jcachex.exceptions - package io.github.dhruv1110.jcachex.exceptions
 
io.github.dhruv1110.jcachex.impl - package io.github.dhruv1110.jcachex.impl
 
io.github.dhruv1110.jcachex.observability - package io.github.dhruv1110.jcachex.observability
 
io.github.dhruv1110.jcachex.resilience - package io.github.dhruv1110.jcachex.resilience
 
io.github.dhruv1110.jcachex.warming - package io.github.dhruv1110.jcachex.warming
 
isEmpty() - Method in class io.github.dhruv1110.jcachex.concurrent.RingBuffer
Checks if the buffer is empty.
isEntryExpired(CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Checks if an entry is expired based on cache configuration.
isExpired() - Method in class io.github.dhruv1110.jcachex.CacheEntry
Fast expiration check using nanoTime
isFull() - Method in class io.github.dhruv1110.jcachex.concurrent.RingBuffer
Checks if the buffer is full.
isHotSpot() - Method in class io.github.dhruv1110.jcachex.warming.WarmingContext.AccessPattern
 
isIdle(K) - Method in class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
Checks if a key is currently idle beyond the threshold.
isInitialized() - Method in class io.github.dhruv1110.jcachex.FrequencySketch
Checks if the sketch has been initialized.
isOverWeight() - Method in class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
Checks if the current weight exceeds the maximum weight.
isReadRepairEnabled() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Returns whether read repair is enabled.
isReadRepairEnabled() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
isRecordStats() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns whether statistics should be recorded for this cache.
isRetryable() - Method in exception io.github.dhruv1110.jcachex.exceptions.CacheException
Returns whether this operation can be retried.
isShutdown() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Checks if the access buffer is shut down.
isSizeLimitReached() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Checks if the cache has reached its maximum size or weight.
isSoftValues() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns whether cache values should be stored using soft references.
isSuccess() - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationResponse
 
isSuccess() - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Returns true if the warming operation was successful.
isValidEntry(E) - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Check if an entry is valid (not expired, not corrupted, etc.).
isValidEntry(CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
isValidValue(V) - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Check if an extracted value should be included in collection views.
isWeakKeys() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns whether cache keys should be stored using weak references.
isWeakValues() - Method in class io.github.dhruv1110.jcachex.CacheConfig
Returns whether cache values should be stored using weak references.

J

JAVA - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.SerializationType
 
JIT_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
JITOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
JIT-optimized cache implementation focused on hot path performance.
JITOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.JITOptimizedCache
 
jitterFactor(double) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Sets the jitter factor to randomize delays.
JSON - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.SerializationType
 
JVM_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
JVMOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
JVM-optimized cache implementation with specialized tuning for the Java Virtual Machine.
JVMOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 

K

key - Variable in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
 
keys() - Method in interface io.github.dhruv1110.jcachex.Cache
Returns a view of all the keys in this cache.
keys() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
keys() - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Common implementation of keys() method.
keys() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
keys() - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
keys() - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
keys() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
keys() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
keys() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
keys() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
keys() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
KRYO - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.SerializationType
 

L

LFU() - Static method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
Basic LFU eviction strategy.
LFUEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Optimized Least Frequently Used (LFU) eviction strategy with O(1) operations.
LFUEvictionStrategy() - Constructor for class io.github.dhruv1110.jcachex.eviction.LFUEvictionStrategy
 
listener(CacheEventListener<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Adds an event listener to the cache.
loadCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the number of times the cache loader was invoked.
loader(Function<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the loader function for automatic value loading.
loader(Function<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the function used to load values synchronously when not present in cache.
loader(Function<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
loader(Function<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
loader(Function<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
loadFailureCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the number of failed cache load operations.
LOADING - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
Data loading errors
loadValue(K) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Load value using configured loader.
local() - Static method in class io.github.dhruv1110.jcachex.CacheFactory
Creates a local cache builder.
LocalCacheBuilder() - Constructor for class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
LOCALITY_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
LOW - io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy.WarmingPriority
 
LRU() - Static method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
Basic LRU eviction strategy.
LRUEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Least Recently Used (LRU) eviction strategy implementation.
LRUEvictionStrategy() - Constructor for class io.github.dhruv1110.jcachex.eviction.LRUEvictionStrategy
 
LZ4 - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CompressionType
 

M

MAINTENANCE - io.github.dhruv1110.jcachex.impl.OptimizedCacheBase.State
 
maintenanceLock - Variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 
maxAttempts(int) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Sets the maximum number of retry attempts.
maxConnections(int) - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
maxDelay(Duration) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Sets the maximum delay between retries.
maximumSize - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
maximumSize(long) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the maximum number of entries the cache may contain.
maximumSize(Long) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the maximum number of entries the cache may contain.
maximumSize(Long) - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
maximumSize(Long) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
maximumSize(Long) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
maximumWeight(long) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the maximum total weight of entries the cache may contain.
maximumWeight(Long) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the maximum total weight of entries the cache may contain.
maxReconnectAttempts(int) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
maxReconnectAttempts(int) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
mean() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Histogram
 
mean() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Timer
 
MEDIUM - io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy.WarmingPriority
 
metricsRegistry(MetricsRegistry) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
metricsRegistry(MetricsRegistry) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
MetricsRegistry - Class in io.github.dhruv1110.jcachex.observability
Central registry for cache metrics and observability.
MetricsRegistry.Builder - Class in io.github.dhruv1110.jcachex.observability
Builder for MetricsRegistry.
MetricsRegistry.Counter - Class in io.github.dhruv1110.jcachex.observability
Counter metric implementation.
MetricsRegistry.Gauge - Class in io.github.dhruv1110.jcachex.observability
Gauge metric implementation.
MetricsRegistry.Histogram - Class in io.github.dhruv1110.jcachex.observability
Histogram metric implementation.
MetricsRegistry.Timer - Class in io.github.dhruv1110.jcachex.observability
Timer metric implementation.
missCount - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
missCount() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the number of cache lookups that didn't find a cached value.
missingWeigher() - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheConfigurationException
Creates a configuration exception for missing weigher function.
missRate() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the ratio of failed cache lookups to total requests.
ML_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
MLOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
ML-based cache implementation with adaptive optimization capabilities.
MLOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
MONOTONIC_READ - io.github.dhruv1110.jcachex.distributed.DistributedCache.ConsistencyLevel
Monotonic read consistency - once a value is read, subsequent reads return the same or a newer value.

N

name(String) - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
name(String) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
name(String) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
needsDraining() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Checks if draining is needed.
needsDraining() - Method in class io.github.dhruv1110.jcachex.concurrent.StripedRingBuffer
Checks if any buffer needs draining.
NetworkProtocol - Interface in io.github.dhruv1110.jcachex.distributed
Network protocol abstraction for distributed cache communication.
NetworkProtocol.CacheOperation - Class in io.github.dhruv1110.jcachex.distributed
Base class for cache operations.
NetworkProtocol.CompressionType - Enum in io.github.dhruv1110.jcachex.distributed
Compression algorithms supported.
NetworkProtocol.GetOperation - Class in io.github.dhruv1110.jcachex.distributed
Get operation for distributed cache.
NetworkProtocol.InvalidateOperation - Class in io.github.dhruv1110.jcachex.distributed
Invalidate operation for distributed cache.
NetworkProtocol.NetworkStats - Class in io.github.dhruv1110.jcachex.distributed
Network protocol statistics.
NetworkProtocol.OperationHandler - Interface in io.github.dhruv1110.jcachex.distributed
Handler for incoming cache operations.
NetworkProtocol.OperationResponse - Class in io.github.dhruv1110.jcachex.distributed
Response to a cache operation.
NetworkProtocol.OperationType - Enum in io.github.dhruv1110.jcachex.distributed
Types of cache operations.
NetworkProtocol.ProtocolBuilder - Class in io.github.dhruv1110.jcachex.distributed
Builder for network protocols.
NetworkProtocol.ProtocolType - Enum in io.github.dhruv1110.jcachex.distributed
Protocol types supported.
NetworkProtocol.PutOperation - Class in io.github.dhruv1110.jcachex.distributed
Put operation for distributed cache.
NetworkProtocol.SerializationType - Enum in io.github.dhruv1110.jcachex.distributed
Serialization formats supported.
NetworkStats(long, long, long, long, double, long) - Constructor for class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.NetworkStats
 
networkTimeout(Duration) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
networkTimeout(Duration) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
newBuilder() - Static method in class io.github.dhruv1110.jcachex.CacheBuilder
Creates a new cache builder.
newBuilder() - Static method in class io.github.dhruv1110.jcachex.CacheConfig
Creates a new builder instance for constructing cache configurations.
NodeInfo(String, String, DistributedCache.NodeStatus, long, Set<Integer>) - Constructor for class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
 
nodes(String...) - Method in class io.github.dhruv1110.jcachex.CacheFactory.AdaptiveCacheBuilder
 
nodes(String...) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
nodes(String...) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
nodes(String...) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
nodes(Collection<String>) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
nodes(Collection<String>) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
nodes(Collection<String>) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
NONE - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CompressionType
 
NONE - io.github.dhruv1110.jcachex.FrequencySketchType
No frequency sketch - simple counting or no frequency tracking.
noOp() - Static method in interface io.github.dhruv1110.jcachex.CacheEventListener
Creates a new CacheEventListener that does nothing.
notifyListeners(Consumer<CacheEventListener<K, V>>) - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Notify all registered event listeners.

O

offer(E) - Method in class io.github.dhruv1110.jcachex.concurrent.RingBuffer
Attempts to add an element to the buffer.
onClear() - Method in interface io.github.dhruv1110.jcachex.CacheEventListener
Called when the cache is cleared.
onEvict(K, V, EvictionReason) - Method in interface io.github.dhruv1110.jcachex.CacheEventListener
Called when a value is evicted from the cache.
onExpire(K, V) - Method in interface io.github.dhruv1110.jcachex.CacheEventListener
Called when a value expires from the cache.
onLoad(K, V) - Method in interface io.github.dhruv1110.jcachex.CacheEventListener
Called when a value is loaded into the cache.
onLoadError(K, Throwable) - Method in interface io.github.dhruv1110.jcachex.CacheEventListener
Called when a value fails to load into the cache.
onPut(K, V) - Method in interface io.github.dhruv1110.jcachex.CacheEventListener
Called when a value is added to the cache.
onRemove(K, V) - Method in interface io.github.dhruv1110.jcachex.CacheEventListener
Called when a value is removed from the cache.
open() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Manually opens the circuit breaker.
OPEN - io.github.dhruv1110.jcachex.resilience.CircuitBreaker.State
 
OPERATION - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
Runtime operation errors
OperationResponse(String, boolean, Object, String) - Constructor for class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationResponse
 
operationState - Variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 
OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
OPTIMIZED - io.github.dhruv1110.jcachex.FrequencySketchType
Optimized frequency sketch with advanced features and optimizations.
OptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
High-performance cache implementation with Caffeine-inspired optimizations.
OptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.OptimizedCache
Creates a new optimized cache with the specified configuration.
OptimizedCacheBase<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Base class for optimized cache implementations providing performance-oriented features.
OptimizedCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Constructor for optimized cache implementations.
OptimizedCacheBase.State - Enum in io.github.dhruv1110.jcachex.impl
Internal state for operation coordination.
OptimizedFrequencySketch<K> - Class in io.github.dhruv1110.jcachex
Ultra-optimized frequency sketch implementation with minimal allocation overhead.
OptimizedFrequencySketch(long) - Constructor for class io.github.dhruv1110.jcachex.OptimizedFrequencySketch
Creates a new optimized frequency sketch.

P

partitionCount(int) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
partitionCount(int) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
performCustomOptimization() - Method in class io.github.dhruv1110.jcachex.impl.AllocationOptimizedCache
Performs allocation-specific optimizations.
performCustomOptimization() - Method in class io.github.dhruv1110.jcachex.impl.JITOptimizedCache
JIT optimization-specific custom optimization.
performCustomOptimization() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCache
Performs custom optimization specific to OptimizedCache.
performCustomOptimization() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Hook for subclasses to perform custom optimization.
performPeriodicMaintenance() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Performs periodic maintenance and optimization.
port(int) - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
processAccessRecord(AccessBuffer.AccessRecord<K>) - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Processes an access record for eviction strategy updates.
PROCESSING - io.github.dhruv1110.jcachex.concurrent.RingBuffer.DrainStatus
 
PROFILED_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
ProfileData() - Constructor for class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache.ProfileData
 
ProfiledOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Profiled and optimized cache implementation with assembly-level performance optimization.
ProfiledOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
ProfiledOptimizedCache.ProfileData - Class in io.github.dhruv1110.jcachex.impl
 
PROTOBUF - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.SerializationType
 
ProtocolBuilder(NetworkProtocol.ProtocolType) - Constructor for class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
put(K, V) - Method in interface io.github.dhruv1110.jcachex.Cache
Associates the specified value with the specified key in this cache.
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Template method for put operation with common validation.
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
PUT - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
 
putAll(K[], V[]) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
SIMD-optimized bulk put operation
putAsync(K, V) - Method in interface io.github.dhruv1110.jcachex.Cache
Asynchronously associates the specified value with the specified key in this cache.
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
PutOperation(String, String, Object, Object, DistributedCache.ConsistencyLevel) - Constructor for class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.PutOperation
 
putWithConsistency(K, V, DistributedCache.ConsistencyLevel) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Puts a value in the cache with the specified consistency level.
putWithConsistency(K, V, DistributedCache.ConsistencyLevel) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 

R

READ - io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessType
 
READ_ONLY_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
ReadOnlyOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Specialized read-only cache implementation optimized for read-heavy workloads.
ReadOnlyOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
rebalance() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Forces a manual rebalancing of the cache across nodes.
rebalance() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
record(double) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Histogram
 
record(Duration) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Timer
 
recordAccess(E) - Method in class io.github.dhruv1110.jcachex.concurrent.StripedRingBuffer
Records an access for the specified element.
recordAccess(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.SegmentedLRU
Records an access to a key, potentially promoting it between segments.
recordAccess(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
Compatibility method for recording access (alias for update).
recordAccess(K, AccessBuffer.AccessType, int) - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Records a cache access operation.
recordAccess(K, AccessBuffer.AccessType, int) - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Records access for frequency analysis and batched processing.
recordClearStatistics(long) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Records statistics for clear operations.
recordEviction() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
recordEviction(AtomicLong, boolean) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Records a cache eviction.
recordGetStatistics(boolean) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Records statistics for get operations.
recordHit() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
recordHit(AtomicLong, boolean) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Records a cache hit in a thread-safe manner.
recordLoad(long) - Method in class io.github.dhruv1110.jcachex.CacheStats
 
recordLoad(AtomicLong, AtomicLong, long, boolean) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Records a cache load operation.
recordLoadFailure() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
recordMiss() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
recordMiss(AtomicLong, boolean) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Records a cache miss in a thread-safe manner.
recordPutStatistics() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Records statistics for put operations.
recordRemoval(K) - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
Compatibility method for recording removal (alias for remove).
recordRemoveStatistics(boolean) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Records statistics for remove operations.
recordStats() - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Enables statistics recording.
recordStats(boolean) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets whether to record statistics.
recordStats(boolean) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets whether statistics should be recorded for this cache.
recoveryTimeout(Duration) - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.Builder
 
refreshAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the refresh duration for automatic cache refresh.
refreshAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the duration after which an entry should be automatically refreshed once the duration has elapsed after the entry's creation or last update.
refreshEntries() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Refresh entries that need refreshing.
registerAlert(String, Supplier<Boolean>) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Registers an alert condition.
registerCache(String, CacheStats) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Registers a cache for monitoring.
registerGauge(String, Supplier<Double>) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Returns a gauge metric.
registerHandler(NetworkProtocol.OperationHandler) - Method in class io.github.dhruv1110.jcachex.distributed.DefaultNetworkProtocol
 
registerHandler(NetworkProtocol.OperationHandler) - Method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Registers a handler for incoming cache operations.
remove(K) - Method in interface io.github.dhruv1110.jcachex.Cache
Removes the mapping for a key from this cache if it is present.
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.CompositeEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLFUEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLRUEvictionStrategy
 
remove(K) - Method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
Removes an entry from the strategy's state.
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.FIFOEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.FILOEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.LFUEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.LRUEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.SegmentedLRU
Removes a key from the segmented LRU.
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Template method for remove operation with common validation.
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
remove(K) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
REMOVE - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
 
removeAsync(K) - Method in interface io.github.dhruv1110.jcachex.Cache
Asynchronously removes the mapping for a key from this cache if it is present.
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
removeNode(String) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Removes a node from the cluster.
removeNode(String) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
replicationFactor(int) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
replicationFactor(int) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
 
replicationFactor(int) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache.Builder
 
REQUIRED - io.github.dhruv1110.jcachex.concurrent.RingBuffer.DrainStatus
 
reset() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
reset() - Method in class io.github.dhruv1110.jcachex.OptimizedFrequencySketch
Reset all counters (periodic aging).
reset() - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker
Resets all circuit breaker statistics.
resetCounters(AtomicLong...) - Static method in class io.github.dhruv1110.jcachex.impl.StatisticsProvider
Resets all statistics counters to zero.
retryOn(Predicate<Throwable>) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Sets a predicate to determine which exceptions should trigger retries.
retryOnException(Class<? extends Throwable>...) - Method in class io.github.dhruv1110.jcachex.resilience.RetryPolicy.Builder
Configures retry only for specific exception types.
RetryPolicy - Class in io.github.dhruv1110.jcachex.resilience
Configurable retry policy for cache operations.
RetryPolicy.Builder - Class in io.github.dhruv1110.jcachex.resilience
Builder class for creating retry policies.
RingBuffer<E> - Class in io.github.dhruv1110.jcachex.concurrent
A striped ring buffer for lock-free access recording in cache operations.
RingBuffer() - Constructor for class io.github.dhruv1110.jcachex.concurrent.RingBuffer
Creates a new ring buffer.
RingBuffer.DrainStatus - Enum in io.github.dhruv1110.jcachex.concurrent
Drain status for coordinating buffer maintenance.

S

sampleSize() - Method in class io.github.dhruv1110.jcachex.FrequencySketch
Returns the current sample size.
scheduleCleanup() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Schedule periodic cleanup of expired entries.
scheduleEviction() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Schedules eviction using the optimized strategy.
scheduleOptimizationTasks() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Schedules periodic optimization tasks.
scheduler - Variable in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
scheduleRefresh() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Schedule refresh operations for entries.
scheduleRefresh() - Method in class io.github.dhruv1110.jcachex.impl.DefaultCache
Schedule refresh operations for entries that support refresh.
SegmentedLRU<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Segmented LRU implementation that divides the LRU into protected and probationary segments.
SegmentedLRU(int) - Constructor for class io.github.dhruv1110.jcachex.eviction.SegmentedLRU
Creates a new segmented LRU with the specified capacity.
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.CompositeEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLFUEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLRUEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
Selects a candidate for eviction from the given entries.
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.FIFOEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.FILOEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.LFUEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.LRUEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
 
selectEvictionCandidate(Map<K, CacheEntry<V>>) - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
 
selectVictim() - Method in class io.github.dhruv1110.jcachex.eviction.SegmentedLRU
Selects a victim for eviction from the appropriate segment.
selectVictims(Map<K, CacheEntry<V>>, int) - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
Selects multiple victims for batch eviction.
send(String, NetworkProtocol.CacheOperation) - Method in class io.github.dhruv1110.jcachex.distributed.DefaultNetworkProtocol
 
send(String, NetworkProtocol.CacheOperation) - Method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Sends a cache operation to the specified node.
serialization(NetworkProtocol.SerializationType) - Method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolBuilder
 
serializationFailure(Object, Throwable) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
Creates an operation exception for serialization failures.
SESSION - io.github.dhruv1110.jcachex.distributed.DistributedCache.ConsistencyLevel
Session consistency - guarantees consistency within the same session/thread.
setReadRepairEnabled(boolean) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
Enables or disables read repair for this cache.
setReadRepairEnabled(boolean) - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
shouldAvoidEvictingNewEntries() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Determines if we should avoid evicting newly added entries.
shouldAvoidEvictingNewEntries() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Determines if we should avoid evicting newly added entries.
shouldWarm(K) - Method in interface io.github.dhruv1110.jcachex.warming.WarmingContext
Checks if a key should be warmed based on context.
shutdown() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
Shuts down the access buffer.
shutdown() - Method in class io.github.dhruv1110.jcachex.impl.AllocationOptimizedCache
Override shutdown to clean up thread-local pools.
shutdown() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
Shutdown the cache and clean up resources.
shutdown() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
shutdown() - Method in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
Shuts down the optimized cache and cleans up resources.
shutdown() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
shutdown() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
SHUTDOWN - io.github.dhruv1110.jcachex.impl.OptimizedCacheBase.State
 
size() - Method in interface io.github.dhruv1110.jcachex.Cache
Returns the approximate number of entries in this cache.
size() - Method in class io.github.dhruv1110.jcachex.concurrent.RingBuffer
Returns the current size of the buffer.
size() - Method in class io.github.dhruv1110.jcachex.eviction.SegmentedLRU
Returns the current size of the segmented LRU.
size() - Method in class io.github.dhruv1110.jcachex.FrequencySketch
Returns the current size counter.
size() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
size() - Method in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
size() - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Common implementation of size() method.
size() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
size() - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
size() - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
size() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
size() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
size() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
size() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
size() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
SIZE - io.github.dhruv1110.jcachex.EvictionReason
The entry was evicted because the cache size limit was reached.
SNAPPY - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CompressionType
 
snapshot() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
softValues() - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Enables soft value references.
softValues(boolean) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Configures the cache to store values using soft references.
start() - Method in class io.github.dhruv1110.jcachex.distributed.DefaultNetworkProtocol
 
start() - Method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Starts the network protocol.
startScheduledWarming(WarmingContext<K, V>, Function<K, V>, ScheduledExecutorService) - Method in interface io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy
Starts scheduled warming if supported by the strategy.
startTime(Instant) - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
StatisticsProvider - Class in io.github.dhruv1110.jcachex.impl
Utility class for common statistics handling patterns.
stats - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
stats() - Method in interface io.github.dhruv1110.jcachex.Cache
Returns the cache statistics.
stats() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Common implementation of stats() method.
stats() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
stats() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
stats() - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
stats() - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
stats() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
stats() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
stats() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
stats() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
stats() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
statsEnabled - Variable in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
 
stop() - Method in class io.github.dhruv1110.jcachex.distributed.DefaultNetworkProtocol
 
stop() - Method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Stops the network protocol.
stopWarming() - Method in interface io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy
Stops any ongoing warming process.
STRIPE_COUNT - Static variable in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
StripedRingBuffer<E> - Class in io.github.dhruv1110.jcachex.concurrent
A collection of striped ring buffers for high-concurrency access recording.
StripedRingBuffer() - Constructor for class io.github.dhruv1110.jcachex.concurrent.StripedRingBuffer
Creates a new striped ring buffer.
stripes - Variable in class io.github.dhruv1110.jcachex.impl.ConcurrentCacheBase
 
STRONG - io.github.dhruv1110.jcachex.distributed.DistributedCache.ConsistencyLevel
Strong consistency - all nodes must agree before operation completes.
success(boolean) - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
success(int, Duration) - Static method in class io.github.dhruv1110.jcachex.warming.WarmingResult
Creates a successful warming result.
success(String, Object) - Static method in class io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationResponse
 
successCount(int) - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
successThreshold(int) - Method in class io.github.dhruv1110.jcachex.resilience.CircuitBreaker.Builder
 
supportsContinuousWarming() - Method in interface io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy
Indicates if this strategy supports continuous warming.

T

tcp() - Static method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Creates a TCP protocol builder.
TCP - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolType
 
TIMEOUT - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
Timeout or performance errors
timer(String) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry
Returns a timer metric.
Timer() - Constructor for class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Timer
 
timestamp - Variable in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
 
TINY_WINDOW_LFU() - Static method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
TinyWindowLFU eviction strategy (hybrid approach).
TOPOLOGY_UPDATE - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
 
toString() - Method in class io.github.dhruv1110.jcachex.CacheStats
 
toString() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
 
toString() - Method in exception io.github.dhruv1110.jcachex.exceptions.CacheException
Returns a comprehensive string representation of this exception.
totalLoadTime() - Method in class io.github.dhruv1110.jcachex.CacheStats
Returns the total time spent loading values, in nanoseconds.
totalSize() - Method in class io.github.dhruv1110.jcachex.concurrent.StripedRingBuffer
Returns the total size across all buffers.
totalTime() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Timer
 
type - Variable in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
 

U

udp() - Static method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Creates a UDP protocol builder.
UDP - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolType
 
UNKNOWN - io.github.dhruv1110.jcachex.EvictionReason
The entry was evicted for an unknown reason.
UNKNOWN - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
Unknown or unclassified errors
UNREACHABLE - io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.CompositeEvictionStrategy
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLFUEvictionStrategy
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.EnhancedLRUEvictionStrategy
 
update(K, CacheEntry<V>) - Method in interface io.github.dhruv1110.jcachex.eviction.EvictionStrategy
Updates the strategy's state when an entry is accessed or modified.
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.FIFOEvictionStrategy
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.FILOEvictionStrategy
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.IdleTimeEvictionStrategy
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.LFUEvictionStrategy
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.LRUEvictionStrategy
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
 
update(K, CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
 
updateExpirationOnAccess(Duration) - Method in class io.github.dhruv1110.jcachex.CacheEntry
Updates the expiration time based on access time.
updateStatsFromCounters() - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Updates the stats object from the atomic counters.

V

validateConfiguration(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.impl.ConfigurationProvider
Validates cache configuration parameters and throws appropriate exceptions.
validateKey(K) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Validates that a key is not null.
validateValue(V) - Method in class io.github.dhruv1110.jcachex.impl.AbstractCacheBase
Validates that a value is not null.
value() - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Gauge
 
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.CacheBuilder.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.concurrent.RingBuffer.DrainStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.DistributedCache.ConsistencyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CompressionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.NetworkProtocol.SerializationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.EvictionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.FrequencySketchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.impl.OptimizedCacheBase.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.resilience.CircuitBreaker.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy.WarmingPriority
Returns the enum constant of this type with the specified name.
values() - Method in interface io.github.dhruv1110.jcachex.Cache
Returns a view of all the values in this cache.
values() - Static method in enum io.github.dhruv1110.jcachex.CacheBuilder.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.concurrent.RingBuffer.DrainStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.distributed.DistributedCache.ConsistencyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.distributed.NetworkProtocol.CompressionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.distributed.NetworkProtocol.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.distributed.NetworkProtocol.SerializationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.EvictionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.FrequencySketchType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
 
values() - Method in class io.github.dhruv1110.jcachex.impl.DataBackedCacheBase
Common implementation of values() method with filtering.
values() - Method in class io.github.dhruv1110.jcachex.impl.DefaultDistributedCache
 
values() - Method in class io.github.dhruv1110.jcachex.impl.HardwareOptimizedCache
 
values() - Method in class io.github.dhruv1110.jcachex.impl.JVMOptimizedCache
 
values() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
 
values() - Static method in enum io.github.dhruv1110.jcachex.impl.OptimizedCacheBase.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
 
values() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
 
values() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 
values() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
values() - Static method in enum io.github.dhruv1110.jcachex.resilience.CircuitBreaker.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy.WarmingPriority
Returns an array containing the constants of this enum type, in the order they are declared.
version - Variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 

W

warm(K, V) - Method in interface io.github.dhruv1110.jcachex.warming.WarmingContext
Warms a single key-value pair.
warmBulk(Map<K, V>) - Method in interface io.github.dhruv1110.jcachex.warming.WarmingContext
Warms multiple key-value pairs.
warmCache(WarmingContext<K, V>, Function<K, V>) - Method in interface io.github.dhruv1110.jcachex.warming.CacheWarmingStrategy
Initiates cache warming process.
WarmingContext<K,​V> - Interface in io.github.dhruv1110.jcachex.warming
Context for cache warming operations.
WarmingContext.AccessPattern - Class in io.github.dhruv1110.jcachex.warming
Represents access patterns for a cache key.
WarmingResult - Class in io.github.dhruv1110.jcachex.warming
Result of a cache warming operation.
WarmingResult.Builder - Class in io.github.dhruv1110.jcachex.warming
Builder for WarmingResult.
warmingStrategy(CacheWarmingStrategy<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheFactory.DistributedCacheBuilder
 
warmingStrategy(CacheWarmingStrategy<K, V>) - Method in class io.github.dhruv1110.jcachex.CacheFactory.LocalCacheBuilder
 
warmUp(Set<K>) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
Warm up the cache by pre-loading frequently accessed data.
warnings(List<String>) - Method in class io.github.dhruv1110.jcachex.warming.WarmingResult.Builder
 
weakKeys() - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Enables weak key references.
weakKeys(boolean) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Configures the cache to store keys using weak references.
weakValues() - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Enables weak value references.
weakValues(boolean) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Configures the cache to store values using weak references.
websocket() - Static method in interface io.github.dhruv1110.jcachex.distributed.NetworkProtocol
Creates a WebSocket protocol builder.
WEBSOCKET - io.github.dhruv1110.jcachex.distributed.NetworkProtocol.ProtocolType
 
weigher(BiFunction<K, V, Long>) - Method in class io.github.dhruv1110.jcachex.CacheBuilder
Sets the weigher function used to calculate entry weights.
weigher(BiFunction<K, V, Long>) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
Sets the weigher function used to calculate entry weights.
WEIGHT - io.github.dhruv1110.jcachex.EvictionReason
The entry was evicted because the cache weight limit was reached.
WeightBasedEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Optimized Weight-based eviction strategy.
WeightBasedEvictionStrategy(long) - Constructor for class io.github.dhruv1110.jcachex.eviction.WeightBasedEvictionStrategy
 
WindowTinyLFUEvictionStrategy<K,​V> - Class in io.github.dhruv1110.jcachex.eviction
Window TinyLFU eviction strategy with frequency-based admission control.
WindowTinyLFUEvictionStrategy(long) - Constructor for class io.github.dhruv1110.jcachex.eviction.WindowTinyLFUEvictionStrategy
Creates a new Window TinyLFU eviction strategy.
windowTinyLFUStrategy - Variable in class io.github.dhruv1110.jcachex.impl.OptimizedCacheBase
 
withDataDog(Object) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Builder
 
withMicrometer(Object) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Builder
 
withPrometheus(Object) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Builder
 
withTag(String, String) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Builder
 
withTags(String...) - Method in class io.github.dhruv1110.jcachex.observability.MetricsRegistry.Builder
 
WRITE - io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessType
 
WRITE_HEAVY_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
WriteHeavyOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Specialized write-heavy cache implementation optimized for write-intensive workloads.
WriteHeavyOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
 

Z

ZERO_COPY_OPTIMIZED - io.github.dhruv1110.jcachex.CacheBuilder.CacheType
 
ZeroCopyOptimizedCache<K,​V> - Class in io.github.dhruv1110.jcachex.impl
Zero-copy optimized cache implementation that minimizes data copying overhead.
ZeroCopyOptimizedCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
 
A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes All Packages