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
All Classes All Packages
All Classes All Packages
A
- AbstractCacheBase<K,V> - Class in io.github.dhruv1110.jcachex.impl.base
-
Abstract base class for all cache implementations providing common functionality.
- AbstractCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Constructor for all cache implementations.
- AbstractCommunicationProtocol<K,V> - Class in io.github.dhruv1110.jcachex.distributed.communication
-
Abstract base class for communication protocol implementations.
- AbstractCommunicationProtocol(CommunicationProtocol.ProtocolConfig) - Constructor for class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- AbstractCommunicationProtocol.CacheOperationRequest - Class in io.github.dhruv1110.jcachex.distributed.communication
-
Internal request structure for cache operations.
- AbstractCommunicationProtocol.CacheOperationResponse - Class in io.github.dhruv1110.jcachex.distributed.communication
-
Internal response structure for cache operations.
- AbstractCommunicationProtocol.InternalCacheHandler<K,V> - Class in io.github.dhruv1110.jcachex.distributed.communication
-
Internal handler for actual cache operations.
- AbstractCommunicationProtocol.OperationType - Enum in io.github.dhruv1110.jcachex.distributed.communication
-
Internal operation types for cache communication.
- AbstractDistributedCache<K,V> - Class in io.github.dhruv1110.jcachex.distributed.impl
-
Abstract base class for distributed cache implementations.
- AbstractDistributedCache(AbstractDistributedCache.Builder<K, V>) - Constructor for class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- AbstractDistributedCache.Builder<K,V> - Class in io.github.dhruv1110.jcachex.distributed.impl
- AbstractDistributedCache.ConsistentHashRing - Class in io.github.dhruv1110.jcachex.distributed.impl
- AbstractDistributedCache.NodeUpdateResult - Class in io.github.dhruv1110.jcachex.distributed.impl
-
Result of node update operations in the consistent hash ring.
- accessBuffer - Variable in class io.github.dhruv1110.jcachex.impl.base.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(WorkloadCharacteristics.AccessPattern) - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
- AccessRecord(K, AccessBuffer.AccessType, long, int) - Constructor for class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
- ACTIVE - io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase.State
- ADAPTIVE - io.github.dhruv1110.jcachex.profiles.ProfileTag
- additionalProperties(Map<String, Object>) - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol.Builder
- 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 class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.ConsistentHashRing
- addNodeDiscoveryListener(NodeDiscovery.NodeDiscoveryListener) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
- addNodeDiscoveryListener(NodeDiscovery.NodeDiscoveryListener) - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Adds a listener for node discovery events.
- ADVANCED - io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Advanced profiles for cutting-edge requirements.
- afterClear() - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Called after clearing the data map.
- 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
- API - io.github.dhruv1110.jcachex.profiles.ProfileTag
- API_CACHE - io.github.dhruv1110.jcachex.profiles.ProfileName
- applyConfiguration(CacheConfig.Builder<K, V>) - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Applies profile-specific configuration to the cache config builder.
- ASYNC - io.github.dhruv1110.jcachex.profiles.ProfileTag
- 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.
- asyncLoader(Function<K, CompletableFuture<V>>) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Sets the function to use for asynchronously loading values.
- averageLoadTime() - Method in class io.github.dhruv1110.jcachex.CacheStats
-
Returns the average time spent loading a value, in nanoseconds.
B
- BALANCED - io.github.dhruv1110.jcachex.profiles.ProfileTag
- BaseDiscoveryBuilder() - Constructor for class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- BASIC - io.github.dhruv1110.jcachex.FrequencySketchType
-
Basic frequency sketch using CountMinSketch with standard parameters.
- beforeClear() - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Called before clearing the data map.
- broadcastBatchInvalidation(Collection<String>, Collection<K>) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- broadcastBatchInvalidation(Collection<String>, Collection<K>) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Broadcast invalidation for multiple keys to multiple nodes.
- broadcastClear(Collection<String>) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- broadcastClear(Collection<String>) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Broadcast cache clear to multiple nodes.
- broadcastInvalidation(Collection<String>, K) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- broadcastInvalidation(Collection<String>, K) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Broadcast invalidation for a single key to multiple nodes.
- bufferSize(int) - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol.Builder
- build() - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
-
Builds and returns a new
CacheConfig
instance with the configured settings. - build() - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol.Builder
- build() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- build() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- build() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
- build() - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- build() - Method in class io.github.dhruv1110.jcachex.distributed.impl.KubernetesDistributedCache.Builder
- build() - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Builds and returns the configured cache instance.
- build() - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Builds the profile without registering it.
- build() - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata.Builder
- build() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
- builder() - Static method in class io.github.dhruv1110.jcachex.CacheConfig
-
Creates a new builder instance for constructing cache configurations.
- builder() - Static method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol
-
Create a new TCP communication protocol builder.
- builder() - Static method in class io.github.dhruv1110.jcachex.distributed.impl.KubernetesDistributedCache
- builder() - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata
- builder() - Static method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- Builder() - Constructor for class io.github.dhruv1110.jcachex.CacheConfig.Builder
- Builder() - Constructor for class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol.Builder
- Builder() - Constructor for class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- Builder() - Constructor for class io.github.dhruv1110.jcachex.distributed.impl.KubernetesDistributedCache.Builder
- Builder() - Constructor for class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata.Builder
- Builder() - Constructor for class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.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.
- CACHE_FRIENDLY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- CacheCommonOperations - Class in io.github.dhruv1110.jcachex.internal.util
-
Consolidated utility class for common cache operations to eliminate code duplication.
- CacheCommonOperations.ImmutableMapEntry<K,V> - Class in io.github.dhruv1110.jcachex.internal.util
-
Immutable Map.Entry implementation - eliminates duplication across multiple implementations.
- cacheConfig - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- cacheConfig(CacheConfig<K, V>) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.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(Function<CacheConfig<?, ?>, Cache<?, ?>>) - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata.Builder
- cacheHandler - Variable in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- 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
- 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.
- CacheOperationRequest(AbstractCommunicationProtocol.OperationType, byte[], byte[]) - Constructor for class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationRequest
- CacheOperationResponse(boolean, byte[], String, Exception) - Constructor for class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationResponse
- CacheProfile<K,V> - Interface in io.github.dhruv1110.jcachex.profiles
-
Strategy pattern interface for cache profiles.
- CacheProfileBuilder - Class in io.github.dhruv1110.jcachex.profiles
-
Builder for creating cache profiles with minimal boilerplate.
- CacheProfilesV3 - Class in io.github.dhruv1110.jcachex.profiles
-
Simplified and standardized cache profiles using the new ProfileRegistry system.
- 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
- calculateAverageLoadTime(long, long) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Calculates the average load time.
- calculateHitRatio(long, long) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Calculates the hit ratio from hit and miss counts.
- calculateMissRatio(long, long) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Calculates the miss ratio from hit and miss counts.
- calculateOptimalCapacity(long) - Static method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Calculates optimal capacity for the underlying ConcurrentHashMap.
- calculateOptimalCapacity(long) - Static method in class io.github.dhruv1110.jcachex.internal.util.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.internal.util.ConfigurationProvider
-
Calculates the optimal concurrency level for concurrent data structures.
- calculateSize(ConcurrentHashMap<?, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Standard size calculation - eliminates duplication across most implementations.
- CAPACITY - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
-
Resource capacity errors
- CAPACITY_LARGE - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Large initial capacity for high-throughput scenarios.
- CAPACITY_MEDIUM - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Medium initial capacity for balanced scenarios.
- CAPACITY_SMALL - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Small initial capacity for memory efficiency.
- CAPACITY_XLARGE - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Extra large initial capacity for enterprise scenarios.
- category(ProfileCategory) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the profile category for grouping.
- category(String) - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata.Builder
- CATEGORY_ADVANCED_DISPLAY - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Display name for advanced category.
- CATEGORY_CORE_DISPLAY - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Display name for core category.
- CATEGORY_CUSTOM_DISPLAY - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Display name for custom category.
- CATEGORY_SPECIALIZED_DISPLAY - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Display name for specialized category.
- checkNodeHealth(String) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
- checkNodeHealth(String) - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Checks the health of a specific node.
- cleanupExpiredEntries() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Clean up expired entries.
- cleanupExpiredEntries() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Cleans 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.base.AbstractCacheBase
-
Template method for clear operation with statistics recording.
- clear() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- clear() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- 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.communication.AbstractCommunicationProtocol.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.base.AbstractCacheBase
- clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
- clearAsync() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
- clearData(ConcurrentHashMap<?, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Standard clear operation - eliminates duplication across most implementations.
- 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.distributed.impl.AbstractDistributedCache
- close() - Method in class io.github.dhruv1110.jcachex.impl.DefaultCache
-
Closes this cache and releases any resources associated with it.
- CLUSTER - io.github.dhruv1110.jcachex.profiles.ProfileTag
- CLUSTER_INFO - io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.OperationType
- clusterName - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- clusterName - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- clusterName(String) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
- clusterName(String) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- clusterNodes - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- ClusterTopology(String, Set<DistributedCache.NodeInfo>, int, long) - Constructor for class io.github.dhruv1110.jcachex.distributed.DistributedCache.ClusterTopology
- communicationProtocol - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- communicationProtocol - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- communicationProtocol(CommunicationProtocol<K, V>) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- CommunicationProtocol<K,V> - Interface in io.github.dhruv1110.jcachex.distributed.communication
-
Simple interface for inter-node communication protocols in distributed cache.
- CommunicationProtocol.CommunicationResult<T> - Class in io.github.dhruv1110.jcachex.distributed.communication
-
Result of a communication operation with type safety.
- CommunicationProtocol.ProtocolConfig - Class in io.github.dhruv1110.jcachex.distributed.communication
-
Simple configuration for the communication protocol.
- CommunicationProtocol.ProtocolType - Enum in io.github.dhruv1110.jcachex.distributed.communication
-
Communication protocol types supported by the system.
- CommunicationResult(boolean, T, String, Exception, Duration) - Constructor for class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- 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
- COMPUTATION - io.github.dhruv1110.jcachex.profiles.ProfileTag
- COMPUTE_CACHE - io.github.dhruv1110.jcachex.profiles.ProfileName
- concurrencyLevel(int) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
-
Sets the concurrency level for the cache's internal data structure.
- concurrencyLevel(WorkloadCharacteristics.ConcurrencyLevel) - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
- ConcurrentCacheBase<K,V> - Class in io.github.dhruv1110.jcachex.impl.base
-
Base class for concurrent cache implementations providing thread-safety primitives.
- ConcurrentCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.base.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.distributed.communication.AbstractCommunicationProtocol
- config - Variable in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- config - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- config() - Method in interface io.github.dhruv1110.jcachex.Cache
-
Returns the cache configuration.
- config() - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Common implementation of config() method.
- config() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- config() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- 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.internal.util
-
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.
- conflictResolutions - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- connectionFailures - Variable in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- connectionTimeout - Variable in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- connectionTimeout(Duration) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- CONSISTENCY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- ConsistentHashRing(int) - Constructor for class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.ConsistentHashRing
- 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.base.AbstractCacheBase
-
Common implementation of containsKey with validation.
- containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
- containsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
- containsKey(K, ConcurrentHashMap<K, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Standard containsKey operation - eliminates duplication across 8+ implementations.
- CORE - io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Core profiles that cover 80% of use cases.
- CPU_OPTIMIZED - io.github.dhruv1110.jcachex.profiles.ProfileTag
- create() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a new builder with the DEFAULT profile.
- create(ProfileName) - Static method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Creates a new profile builder for a predefined profile.
- createAsyncClear(Runnable) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard async clear operation - eliminates duplication across 8+ implementations.
- createAsyncGet(K, Supplier<V>) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard async get operation - eliminates duplication across 8+ implementations.
- createAsyncPut(K, V, Runnable) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard async put operation - eliminates duplication across 8+ implementations.
- createAsyncRemove(K, Supplier<V>) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard async remove operation - eliminates duplication across 8+ implementations.
- createBasicConfig(long, boolean) - Static method in class io.github.dhruv1110.jcachex.internal.util.ConfigurationProvider
-
Creates a basic configuration object with minimal settings.
- createBasicStats(AtomicLong, AtomicLong) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Creates a basic CacheStats object from hit and miss counters.
- createCache(String, CacheConfig<K, V>) - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Creates a cache instance using the specified profile.
- createCacheEntry(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Creates a cache entry with proper weight calculation.
- 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.base.AbstractCacheBase
-
Creates a cache entry with proper timestamp and expiration settings.
- createCacheEntry(V) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Creates a cache entry with proper weight calculation.
- createComprehensiveStats(AtomicLong, AtomicLong, AtomicLong, AtomicLong, AtomicLong) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates comprehensive cache statistics.
- createComprehensiveStats(AtomicLong, AtomicLong, AtomicLong, AtomicLong, AtomicLong) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Creates a comprehensive CacheStats object with all counters.
- createConfig(long, boolean) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard cache configuration - eliminates duplication across 8+ implementations.
- createEntriesView(ConcurrentHashMap<K, E>, Function<E, V>) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard entries view with entry extraction - eliminates duplication across 8+ implementations.
- createKeysView(ConcurrentHashMap<K, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard keys view - eliminates duplication across all implementations.
- createMapEntry(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Create a Map.Entry for the entries() collection view.
- createMapEntry(K, V) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates an immutable map entry - eliminates duplication of inner classes.
- createSizeWeightConfig(long, long, boolean) - Static method in class io.github.dhruv1110.jcachex.internal.util.ConfigurationProvider
-
Creates a configuration object with size and weight limits.
- createStats(AtomicLong, AtomicLong) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard cache statistics - eliminates duplication across 8+ implementations.
- createValuesView(ConcurrentHashMap<K, E>, Function<E, V>) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Creates standard values view with entry extraction - eliminates duplication across 8+ implementations.
- currentMemoryBytes - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- currentNodeId - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- currentSize - Variable in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- currentSize - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- currentWeight - Variable in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- currentWeight - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- CUSTOM - io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Custom profiles created by users.
D
- data - Variable in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
- data - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- DataBackedCacheBase<K,V,E> - Class in io.github.dhruv1110.jcachex.impl.base
-
Abstract base class for cache implementations that store data in a ConcurrentHashMap.
- DataBackedCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Constructor for data-backed cache implementations.
- DEFAULT - io.github.dhruv1110.jcachex.profiles.ProfileName
- DEFAULT - io.github.dhruv1110.jcachex.profiles.ProfileTag
- DEFAULT - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata
- DEFAULT_DRAIN_INTERVAL_NANOS - Static variable in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
- DEFAULT_DRAIN_THRESHOLD - Static variable in class io.github.dhruv1110.jcachex.impl.base.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.
- defaultConcurrencyLevel(int) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the default concurrency level.
- defaultExpiration(Duration) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the default expiration time for cache entries.
- defaultExpireAfterAccess(Duration) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the default expire-after-access duration.
- defaultExpireAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the default expire-after-write duration.
- defaultInitialCapacity(int) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the default initial capacity.
- defaultMaximumSize(long) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the default maximum size for caches using this profile.
- defaultRecordStats(boolean) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets whether statistics recording is enabled by default.
- defaultRefreshAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the default refresh-after-write duration.
- DEGRADED - io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
- description(String) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the profile description.
- description(String) - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata.Builder
- deserializeObject(byte[]) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- DEVELOPMENT - io.github.dhruv1110.jcachex.profiles.ProfileTag
- DIRECT_MEMORY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- directory(String) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
-
Sets the directory path for persistent cache storage.
- DiscoveredNode(String, String, int, NodeDiscovery.NodeHealth, Instant, Map<String, String>) - Constructor for class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveredNode
- discoverNodes() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
- discoverNodes() - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Discovers all available nodes in the cluster.
- discoveryInterval - Variable in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- discoveryInterval(Duration) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- discoveryScheduler - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- DiscoveryStats(long, long, long, long, long, long) - Constructor for class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryStats
- DISTRIBUTED - io.github.dhruv1110.jcachex.profiles.ProfileTag
- 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.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.
- DistributedMetrics(long, long, double, long, long, Map<String, Long>) - Constructor for class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
- distributionExecutor - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- doClear() - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Implementation-specific clear operation.
- doClear() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- doClear() - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Common clear implementation.
- doClear() - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Enhanced clear operation with versioning.
- doClear() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Implementation-specific clear operation.
- doContainsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Implementation-specific containsKey operation.
- doContainsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- doContainsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Common implementation of containsKey with entry validation.
- doContainsKey(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Implementation-specific containsKey operation.
- doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Implementation-specific get operation.
- doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Optimized get operation with lock-free reads where possible.
- doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Implementation-specific get operation.
- doGet(K) - Method in class io.github.dhruv1110.jcachex.impl.JITOptimizedCache
-
Override to use JIT-optimized read path.
- doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Implementation-specific put operation.
- doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Optimized put operation with batched processing.
- doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Implementation-specific put operation.
- doPut(K, V) - Method in class io.github.dhruv1110.jcachex.impl.JITOptimizedCache
-
Override to use JIT-optimized write path.
- doRemove(K) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Implementation-specific remove operation.
- doRemove(K) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- doRemove(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Implementation-specific remove operation.
- 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.base.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.
E
- empty() - Static method in class io.github.dhruv1110.jcachex.CacheStats
- enableReadOnlyMode() - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
-
Enable read-only mode for maximum read performance.
- enableReadRepair(boolean) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- enforceSize() - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Hook for subclasses to perform size enforcement.
- enforceSize() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Override size enforcement to use eviction strategy.
- enforceSize() - Method in class io.github.dhruv1110.jcachex.impl.base.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.
- ENTERPRISE - io.github.dhruv1110.jcachex.profiles.ProfileTag
- 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.base.DataBackedCacheBase
-
Common implementation of entries() method with filtering.
- entries() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- entries() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- 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
- equals(Object) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase.ImmutableMapEntry
- equals(Object) - Method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations.ImmutableMapEntry
- estimateSize(K, V) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- eventListener - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- EVICT - io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessType
- evictEntries() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- evictEntries(K) - Method in class io.github.dhruv1110.jcachex.impl.base.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.base.ConcurrentCacheBase
- evictionStrategy - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- evictionStrategy(EvictionStrategy<Object, Object>) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the eviction strategy.
- 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.
- evictToFreeMemory(long) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- expectedSize(long) - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
- EXPERIMENTAL - io.github.dhruv1110.jcachex.profiles.ProfileTag
- EXPIRATION - io.github.dhruv1110.jcachex.profiles.ProfileTag
- EXPIRATION_LONG - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Long expiration time for session data (30 minutes).
- EXPIRATION_MEDIUM - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Medium expiration time for API responses (15 minutes).
- EXPIRATION_SHORT - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Short expiration time for temporary data (5 minutes).
- EXPIRATION_XLONG - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Extra long expiration time for computation results (2 hours).
- 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.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.JCacheXBuilder
-
Sets the duration after which entries are automatically removed after access.
- 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.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.JCacheXBuilder
-
Sets the duration after which entries are automatically removed after write.
- 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.
- EXTERNAL - io.github.dhruv1110.jcachex.profiles.ProfileTag
- extractValue(E) - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Extract the value from an entry.
- extractValue(CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
F
- factory(Function<CacheConfig<?, ?>, Cache<?, ?>>) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets a custom cache factory function.
- FAILED - io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
- failure(String, Exception) - Static method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationResponse
- failure(String, Exception) - Static method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- 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
- finalize() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
-
Cleanup resources when cache is garbage collected
- findSuitableProfiles(WorkloadCharacteristics) - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Finds profiles suitable for the given workload characteristics.
- flushWrites() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
-
Flush all pending writes to main storage.
- forApiResponseCaching() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for API response caching.
- forceDrain(Consumer<AccessBuffer.AccessRecord<K>>) - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer
-
Forces an immediate drain of all pending accesses.
- forComputationCaching() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for expensive computation results.
- forHardwareOptimization() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for hardware-specific features.
- forHighConcurrency() - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Convenience method for high-concurrency workloads.
- forHighPerformance() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for maximum performance and throughput.
- forMachineLearning() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for machine learning workloads.
- formatDetailedMetrics(long, long, long, long, long, long) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Creates a detailed performance metrics string.
- formatStatsSummary(long, long, long, long) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Creates a formatted statistics summary string.
- forMemoryConstrained() - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Convenience method for memory-constrained environments.
- forMemoryConstrainedEnvironment() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for memory-constrained environments.
- forProfile(CacheProfile<?, ?>) - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a new builder with the specified cache profile.
- forReadHeavy() - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Convenience method for read-heavy workloads.
- forReadHeavyWorkload() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for read-heavy workloads (80%+ reads).
- forSessionStorage() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for user session storage.
- forUltraLowLatency() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for ultra-low latency requirements.
- forWriteHeavy() - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Convenience method for write-heavy workloads.
- forWriteHeavyWorkload() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a builder optimized for write-heavy workloads (50%+ writes).
- 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.base.OptimizedCacheBase
- frequencySketch - Variable in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
- frequencySketch(FrequencySketchType) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the frequency sketch type.
- 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.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.
- fromProfile(ProfileName) - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a new builder with the specified cache profile using ProfileName enum for type safety.
- fromValue(String) - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Finds a ProfileName by its string value.
- fromValue(String) - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileTag
-
Finds a ProfileTag by its string value.
G
- GC_SENSITIVE - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.MemoryConstraint
-
Constrained by GC pressure
- GENERAL - io.github.dhruv1110.jcachex.profiles.ProfileTag
- generateNodeId() - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
-
Generate a unique node ID for this cache instance.
- generateNodeId() - Method in class io.github.dhruv1110.jcachex.distributed.impl.KubernetesDistributedCache
- get() - Static method in class io.github.dhruv1110.jcachex.internal.util.SchedulerProvider
- 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 interface io.github.dhruv1110.jcachex.distributed.DistributedCache
- get(K) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- get(K) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Template method for get operation with common validation and statistics.
- get(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- get(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
-
Ultra-fast get operation with minimal overhead.
- 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.communication.AbstractCommunicationProtocol.OperationType
- getAccessCount() - Method in class io.github.dhruv1110.jcachex.CacheEntry
- getAccessPattern() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- getActiveNodes() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryStats
- getAdditionalProperties() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolConfig
- getAddress() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveredNode
- getAddress() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
- getAdvancedProfiles() - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Gets all advanced profile names.
- 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.
- getAllProfileNames() - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Gets all profile names.
- getAllProfiles() - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Gets all registered profiles.
- 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 interface io.github.dhruv1110.jcachex.distributed.DistributedCache
-
Gets a value from the cache with the specified consistency level.
- getAsync(K) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- getAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- 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.
- getAverageDiscoveryTime() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryStats
- getAverageNetworkLatency() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
- getBufferSize() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolConfig
- getCacheFactory() - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata
- getCacheImplementation() - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Returns the recommended cache implementation class for this profile.
- getCapacity() - Method in class io.github.dhruv1110.jcachex.FrequencySketch
-
Returns the current capacity of the frequency sketch.
- getCategory() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Gets the category this profile belongs to.
- getCategory() - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata
- 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.distributed.impl.KubernetesDistributedCache
- getConcurrencyLevel() - Method in class io.github.dhruv1110.jcachex.CacheConfig
-
Returns the concurrency level for the cache's internal data structure.
- getConcurrencyLevel() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- getConfig() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- getConfig() - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Get the protocol configuration.
- getConfigurationSummary() - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Returns information about the builder's current configuration.
- getConflictResolutions() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
- getConsolidationImpact() - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Returns a summary of the consolidation impact.
- 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.
- getCoreProfiles() - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Gets all core profile names.
- 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
- 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.base.AbstractCacheBase
-
Calculates the current total weight of entries in the cache.
- getCurrentWeight() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- getDataMap() - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Get direct access to the underlying data map.
- getDefaultProfile() - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Gets the default profile.
- getDescription() - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Returns a description of this cache profile and its intended use case.
- getDescription() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Gets the description of this category.
- getDescription() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Gets the description of this profile.
- getDescription() - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata
- getDescription() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileTag
-
Gets the description of this tag.
- 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.
- getDiscoveryStats() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
- getDiscoveryStats() - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Gets discovery statistics.
- getDiscoveryType() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
- getDiscoveryType() - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Gets the discovery type.
- getDisplayName() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Gets the human-readable display name for this category.
- getDistributedMetrics() - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache
-
Returns detailed metrics about distributed operations.
- getDistributedMetrics() - Method in class io.github.dhruv1110.jcachex.distributed.impl.KubernetesDistributedCache
- getDrainStatus() - Method in class io.github.dhruv1110.jcachex.concurrent.RingBuffer
-
Gets the current drain status.
- getError() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationResponse
- getError() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- 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.communication.AbstractCommunicationProtocol.CacheOperationResponse
- getErrorMessage() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- 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.
- getEvictionStrategy() - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Returns the optimal eviction strategy for this profile.
- getExpectedSize() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- 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.
- getFailedDiscoveries() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryStats
- 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.
- getFromRemoteNode(String, K) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- getFullAddress() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveredNode
- getHealth() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveredNode
- 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().
- getHitRateExpectation() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- 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.impl.base.UnifiedCacheBase.ImmutableMapEntry
- getKey() - Method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations.ImmutableMapEntry
- getKeyData() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationRequest
- getLastAccessTime() - Method in class io.github.dhruv1110.jcachex.CacheEntry
-
Get last access time as Instant (created lazily for compatibility)
- 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.discovery.NodeDiscovery.DiscoveredNode
- getLastSeen() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
- getLatency() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationResponse
- getLatency() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- 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.
- getMaxConnections() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolConfig
- 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.
- getMemoryConstraint() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- getMetadata() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveredNode
- getMetadata(String) - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Gets metadata for a profile.
- getMetrics() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- getMetrics() - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Get protocol-specific 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().
- getName() - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Returns the name of this cache profile.
- getNetworkFailures() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
- getNetworkRequests() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
- getNetworkSuccessRate() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
- getNodeForKey(String) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.ConsistentHashRing
- getNodeId() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveredNode
- 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.distributed.impl.KubernetesDistributedCache
- getOperation() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationRequest
- getOperationState() - Method in class io.github.dhruv1110.jcachex.impl.base.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.base.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.distributed.impl.KubernetesDistributedCache
- getPort() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolConfig
- getPort() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveredNode
- getPriority() - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata
- getProfile(String) - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Gets a profile by name.
- getProfileData() - Method in class io.github.dhruv1110.jcachex.impl.ProfiledOptimizedCache
- getProtocolType() - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Get the protocol type.
- getProtocolType() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolConfig
- getProtocolType() - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol
- getReadLock(K) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Get read lock for a specific key.
- getReadToWriteRatio() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- getRecommendedConcurrencyLevel() - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Returns the recommended concurrency level for this profile.
- getRecommendedInitialCapacity(long) - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Returns the recommended initial capacity for this profile.
- 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.distributed.impl.KubernetesDistributedCache
- getReplicationLag() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.DistributedMetrics
- getResult() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationResponse
- getResult() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- getSafeInitialCapacity(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.ConfigurationProvider
-
Gets a safe initial capacity value, handling null cases.
- getSafeMaximumSize(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.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.
- getSortOrder() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Gets the sort order for this category (lower numbers first).
- getSpecializedProfiles() - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Gets all specialized profile names.
- 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.base.ConcurrentCacheBase
-
Get the stripe index for a key to enable striped locking.
- getStripeIndex(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Gets the stripe index for a key.
- getSuccessfulDiscoveries() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryStats
- getSuccessRate() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryStats
- getTags() - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata
- getTimeoutMs() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolConfig
- getTimestamp() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- getTotalDiscoveries() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryStats
- getTotalLoadTime() - Method in class io.github.dhruv1110.jcachex.CacheStats
- getTotalNodesDiscovered() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryStats
- getValue() - Method in class io.github.dhruv1110.jcachex.CacheEntry
- getValue() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase.ImmutableMapEntry
- getValue() - Method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations.ImmutableMapEntry
- getValue() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Gets the string value of this profile name.
- getValue() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileTag
-
Gets the string value of this tag.
- getValueData() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationRequest
- getVersion() - Method in class io.github.dhruv1110.jcachex.distributed.DistributedCache.ClusterTopology
- getVersion() - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Returns the current version for optimistic concurrency control.
- 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.
- getWriteCount() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
-
Get write statistics.
- getWriteLock(K) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Get write lock for a specific key.
H
- handleOperation(AbstractCommunicationProtocol.CacheOperationRequest) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.InternalCacheHandler
- HARDWARE - io.github.dhruv1110.jcachex.profiles.ProfileTag
- HARDWARE_OPTIMIZED - io.github.dhruv1110.jcachex.profiles.ProfileName
- 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.base.AbstractCacheBase
- hasExpiration - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- hasExpiration(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.ConfigurationProvider
-
Checks if the configuration has expiration settings.
- hashCode() - Method in class io.github.dhruv1110.jcachex.CacheStats
- hashCode() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase.ImmutableMapEntry
- hashCode() - Method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations.ImmutableMapEntry
- hashRing - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- hasLoader(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.ConfigurationProvider
-
Checks if the configuration has loading capability.
- hasMaximumSize - Variable in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- hasMaximumSize - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- hasMaximumWeight - Variable in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- hasMaximumWeight - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- hasMemoryConstraints() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
-
Returns true if this workload has memory constraints.
- hasRefresh(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.ConfigurationProvider
-
Checks if the configuration has refresh settings.
- HEALTH_CHECK - io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.OperationType
- healthCheckInterval - Variable in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- healthCheckInterval(Duration) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- HEALTHY - io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.NodeHealth
- HEALTHY - io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeStatus
- healthyNodes - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- HFT - io.github.dhruv1110.jcachex.profiles.ProfileTag
- HIGH - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.ConcurrencyLevel
-
High concurrency - many concurrent threads
- HIGH_CONCURRENCY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- HIGH_PERFORMANCE - io.github.dhruv1110.jcachex.profiles.ProfileName
- hitCount - Variable in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- hitCount - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- 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.
- hitRateExpectation(double) - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
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
- ImmutableMapEntry(K, V) - Constructor for class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase.ImmutableMapEntry
- ImmutableMapEntry(K, V) - Constructor for class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations.ImmutableMapEntry
- implementation(Class<? extends Cache>) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the cache implementation class.
- 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.CacheConfig.Builder
-
Sets the initial capacity of the cache's internal data structure.
- initializeCluster() - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
-
Initialize cluster-specific functionality.
- initializeCluster() - Method in class io.github.dhruv1110.jcachex.distributed.impl.KubernetesDistributedCache
- INTELLIGENT - io.github.dhruv1110.jcachex.profiles.ProfileTag
- InternalCacheHandler() - Constructor for class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.InternalCacheHandler
- 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.distributed.impl.AbstractDistributedCache
- 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.distributed.impl.AbstractDistributedCache
- 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.distributed.communication - package io.github.dhruv1110.jcachex.distributed.communication
- io.github.dhruv1110.jcachex.distributed.discovery - package io.github.dhruv1110.jcachex.distributed.discovery
- io.github.dhruv1110.jcachex.distributed.impl - package io.github.dhruv1110.jcachex.distributed.impl
- 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.impl.base - package io.github.dhruv1110.jcachex.impl.base
- io.github.dhruv1110.jcachex.internal.util - package io.github.dhruv1110.jcachex.internal.util
- io.github.dhruv1110.jcachex.profiles - package io.github.dhruv1110.jcachex.profiles
- isAdvanced() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Checks if this is an advanced category.
- isAdvanced() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Checks if this is an advanced profile.
- isCore() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Checks if this is a core category.
- isCore() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Checks if this is a core profile.
- 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.base.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.
- 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.
- isReadHeavy() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
-
Returns true if this workload is read-heavy (ratio > 5.0).
- isRecordStats() - Method in class io.github.dhruv1110.jcachex.CacheConfig
-
Returns whether statistics should be recorded for this cache.
- isRegistered(String) - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Checks if a profile is registered.
- isRequiresAsyncOperations() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- isRequiresConsistency() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
- isRetryable() - Method in exception io.github.dhruv1110.jcachex.exceptions.CacheException
-
Returns whether this operation can be retried.
- isRunning - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- isRunning() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- isRunning() - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Check if the protocol is currently running.
- 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.base.AbstractCacheBase
-
Checks if the cache has reached its maximum size or weight.
- isSizeLimitReached() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Checks if size limit has been reached.
- isSoftValues() - Method in class io.github.dhruv1110.jcachex.CacheConfig
-
Returns whether cache values should be stored using soft references.
- isStatisticsEnabledByDefault() - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Returns whether statistics should be enabled by default for this profile.
- isSuccess() - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationResponse
- isSuccess() - Method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- isSuitableFor(WorkloadCharacteristics) - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Returns whether this profile is suitable for the given workload characteristics.
- isValidEntry(E) - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Check if an entry is valid (not expired, not corrupted, etc.).
- isValidEntry(CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- isValidEntry(CacheEntry<V>) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Checks if an entry is valid (not expired, etc.).
- isValidKey(Object) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Standard null key validation - eliminates duplication across all implementations.
- isValidValue(Object) - Static method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations
-
Standard null value validation - eliminates duplication across all implementations.
- isValidValue(V) - Method in class io.github.dhruv1110.jcachex.impl.base.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.
- isWriteHeavy() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
-
Returns true if this workload is write-heavy (ratio < 1.0).
J
- JCacheXBuilder<K,V> - Class in io.github.dhruv1110.jcachex
-
The unified cache builder for JCacheX that simplifies cache creation using profiles and smart defaults.
- 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
- 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.base.DataBackedCacheBase
-
Common implementation of keys() method.
- keys() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- keys() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- keys() - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
- keys() - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
- kubeConfigPath - Variable in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- kubeConfigPath(String) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- kubernetes() - Static method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Creates a Kubernetes-based node discovery.
- KUBERNETES - io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryType
- KubernetesDiscoveryBuilder() - Constructor for class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- KubernetesDistributedCache<K,V> - Class in io.github.dhruv1110.jcachex.distributed.impl
-
Kubernetes-specific distributed cache implementation.
- KubernetesDistributedCache.Builder<K,V> - Class in io.github.dhruv1110.jcachex.distributed.impl
- KubernetesNodeDiscovery - Class in io.github.dhruv1110.jcachex.distributed.discovery
-
Kubernetes-based node discovery implementation using the official Kubernetes Java client.
- KubernetesNodeDiscovery(NodeDiscovery.KubernetesDiscoveryBuilder) - Constructor for class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
L
- labelSelector - Variable in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- labelSelector(String) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- 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
- LIMITED - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.MemoryConstraint
-
Limited memory available
- listener(CacheEventListener<K, V>) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
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.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.JCacheXBuilder
-
Sets the function to use for loading values when keys are not present.
- 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.base.ConcurrentCacheBase
-
Load value using configured loader.
- localCache - Variable in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- localCache - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- LOCK_FREE - io.github.dhruv1110.jcachex.profiles.ProfileTag
- LOG_PROFILE_CREATED - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Log message for profile creation.
- LOG_PROFILE_DISCOVERY - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Log message for profile discovery.
- LOG_PROFILE_INIT_COMPLETE - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Log message for profile initialization completion.
- LOG_PROFILE_INIT_START - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Log message for profile initialization.
- LOG_PROFILE_REGISTERED - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Log message for profile registration.
- logger - Static variable in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- LOGGER_NAME - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Logger name for profile-related operations.
- LOW - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.ConcurrencyLevel
-
Low concurrency - few threads
- LOW_LATENCY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- 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
M
- MACHINE_LEARNING - io.github.dhruv1110.jcachex.profiles.ProfileTag
- MAINTENANCE - io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase.State
- maintenanceLock - Variable in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
- MAX_DESCRIPTION_LENGTH - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Maximum description length.
- MAX_NAME_LENGTH - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Maximum profile name length.
- MAX_PRIORITY - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Maximum allowed priority value.
- MAX_TAGS_PER_PROFILE - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Maximum number of tags per profile.
- maxConnections(int) - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol.Builder
- maximumSize - Variable in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- maximumSize - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- maximumSize(long) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
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.
- maximumWeight(long) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
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.
- maxMemoryBytes - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- maxMemoryBytes - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- maxMemoryMB(long) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- maxReconnectAttempts(int) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
- maxRetries - Variable in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- maxRetries(int) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.BaseDiscoveryBuilder
- MEDIUM - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.ConcurrencyLevel
-
Medium concurrency - moderate thread count
- MEMORY_CONSTRAINED - io.github.dhruv1110.jcachex.profiles.ProfileTag
- MEMORY_EFFICIENT - io.github.dhruv1110.jcachex.profiles.ProfileName
- MEMORY_EFFICIENT - io.github.dhruv1110.jcachex.profiles.ProfileTag
- memoryConstraint(WorkloadCharacteristics.MemoryConstraint) - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
- messagesReceived - Variable in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- messagesSent - Variable in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- MIGRATE_KEYS - io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.OperationType
- migrateData(String, String, Set<String>) - Method in class io.github.dhruv1110.jcachex.distributed.impl.KubernetesDistributedCache
- MIN_PRIORITY - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Minimum allowed priority value.
- missCount - Variable in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- missCount - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- 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.
- MIXED - io.github.dhruv1110.jcachex.profiles.ProfileTag
- MIXED - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.AccessPattern
-
Mixed access pattern
- ML_OPTIMIZED - io.github.dhruv1110.jcachex.profiles.ProfileName
- 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
N
- name(String) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Sets the cache name for identification and debugging.
- namespace - Variable in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- namespace(String) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- 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.
- NETWORK - io.github.dhruv1110.jcachex.profiles.ProfileTag
- NETWORK_AWARE - io.github.dhruv1110.jcachex.profiles.ProfileTag
- networkFailures - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- networkRequests - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- networkTimeout - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- networkTimeout - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- networkTimeout(Duration) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
- networkTimeout(Duration) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- newBuilder() - Static method in class io.github.dhruv1110.jcachex.CacheConfig
-
Creates a new builder instance for constructing cache configurations.
- nodeDiscovery - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- nodeDiscovery - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- nodeDiscovery(NodeDiscovery) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- NodeDiscovery - Interface in io.github.dhruv1110.jcachex.distributed.discovery
-
Interface for discovering cache nodes in distributed environments.
- NodeDiscovery.BaseDiscoveryBuilder<T extends NodeDiscovery.BaseDiscoveryBuilder<T>> - Class in io.github.dhruv1110.jcachex.distributed.discovery
-
Base builder for node discovery implementations.
- NodeDiscovery.DiscoveredNode - Class in io.github.dhruv1110.jcachex.distributed.discovery
-
Information about a discovered node.
- NodeDiscovery.DiscoveryStats - Class in io.github.dhruv1110.jcachex.distributed.discovery
-
Discovery statistics.
- NodeDiscovery.DiscoveryType - Enum in io.github.dhruv1110.jcachex.distributed.discovery
-
Discovery strategy types.
- NodeDiscovery.KubernetesDiscoveryBuilder - Class in io.github.dhruv1110.jcachex.distributed.discovery
-
Builder for Kubernetes node discovery.
- NodeDiscovery.NodeDiscoveryListener - Interface in io.github.dhruv1110.jcachex.distributed.discovery
-
Listener for node discovery events.
- NodeDiscovery.NodeHealth - Enum in io.github.dhruv1110.jcachex.distributed.discovery
-
Node health status.
- NodeInfo(String, String, DistributedCache.NodeStatus, long, Set<Integer>) - Constructor for class io.github.dhruv1110.jcachex.distributed.DistributedCache.NodeInfo
- NONE - io.github.dhruv1110.jcachex.FrequencySketchType
-
No frequency sketch - simple counting or no frequency tracking.
- NONE - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.MemoryConstraint
-
No memory constraints
- 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.base.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.
- onNodeDiscovered(NodeDiscovery.DiscoveredNode) - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.NodeDiscoveryListener
-
Called when a new node is discovered.
- onNodeHealthChanged(String, NodeDiscovery.NodeHealth, NodeDiscovery.NodeHealth) - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.NodeDiscoveryListener
-
Called when a node's health status changes.
- onNodeLost(String) - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.NodeDiscoveryListener
-
Called when a node is no longer available.
- 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.
- OPERATION - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
-
Runtime operation errors
- operationState - Variable in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
- 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
-
Base class for optimized cache implementations providing performance-oriented features.
- OptimizedCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Constructor for optimized cache implementations.
- OptimizedCacheBase.State - Enum in io.github.dhruv1110.jcachex.impl.base
-
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
- PARALLEL - io.github.dhruv1110.jcachex.profiles.ProfileTag
- partitionCount - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- partitionCount - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- partitionCount(int) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
- partitionCount(int) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- PERFORMANCE - io.github.dhruv1110.jcachex.profiles.ProfileTag
- performCustomOptimization() - Method in class io.github.dhruv1110.jcachex.impl.AllocationOptimizedCache
-
Performs allocation-specific optimizations.
- performCustomOptimization() - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Hook for subclasses to perform custom optimization.
- 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.
- performPeriodicMaintenance() - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Performs periodic maintenance and optimization.
- perNodeLatencies - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- port(int) - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol.Builder
- PREDICTIVE - io.github.dhruv1110.jcachex.profiles.ProfileTag
- priority(int) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the profile priority for automatic selection.
- priority(int) - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata.Builder
- PRIORITY_DEFAULT - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Default priority for profiles that should be used as fallbacks.
- PRIORITY_HIGH - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
High priority for preferred profiles.
- PRIORITY_LOW - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Low priority for less preferred profiles.
- PRIORITY_NORMAL - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Normal priority for standard profiles.
- PRIORITY_VERY_HIGH - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Very high priority for specialized profiles.
- processAccessRecord(AccessBuffer.AccessRecord<K>) - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Processes an access record for eviction strategy updates.
- PROCESSING - io.github.dhruv1110.jcachex.concurrent.RingBuffer.DrainStatus
- PRODUCTION - io.github.dhruv1110.jcachex.profiles.ProfileTag
- ProfileCategory - Enum in io.github.dhruv1110.jcachex.profiles
-
Enum representing different categories of cache profiles.
- ProfileConstants - Class in io.github.dhruv1110.jcachex.profiles
-
Constants used throughout the cache profile system.
- 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
- ProfileName - Enum in io.github.dhruv1110.jcachex.profiles
-
Enum containing all predefined cache profile names.
- ProfileRegistry - Class in io.github.dhruv1110.jcachex.profiles
-
Centralized registry for all cache profiles.
- ProfileRegistry.ProfileMetadata - Class in io.github.dhruv1110.jcachex.profiles
-
Metadata about a cache profile.
- ProfileRegistry.ProfileMetadata.Builder - Class in io.github.dhruv1110.jcachex.profiles
- ProfileTag - Enum in io.github.dhruv1110.jcachex.profiles
-
Enum containing common tags used for cache profiles.
- ProtocolConfig(CommunicationProtocol.ProtocolType, int, long, int, int, Map<String, Object>) - Constructor for class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolConfig
- 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 interface io.github.dhruv1110.jcachex.distributed.DistributedCache
- put(K, V) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Template method for put operation with common validation.
- put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- put(K, V) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
-
Ultra-fast put operation with efficient eviction.
- 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.communication.AbstractCommunicationProtocol.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 interface io.github.dhruv1110.jcachex.distributed.DistributedCache
-
Puts a value in the cache with the specified consistency level.
- putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
- putAsync(K, V) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
- putToRemoteNode(String, K, V) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
R
- RANDOM - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.AccessPattern
-
Random access pattern - requires fast lookup
- READ - io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessType
- READ_HEAVY - io.github.dhruv1110.jcachex.profiles.ProfileName
- READ_HEAVY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- 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
- readRepairEnabled - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- readRepairEnabled - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- readToWriteRatio(double) - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
- 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.distributed.impl.AbstractDistributedCache
- rebalance(Set<String>) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.ConsistentHashRing
- rebalance(Set<String>) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- 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.base.OptimizedCacheBase
-
Records access for frequency analysis and batched processing.
- recordClearStatistics(long) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Records statistics for clear operations.
- recordClearStatistics(long) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
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.internal.util.StatisticsProvider
-
Records a cache eviction.
- recordGetStatistics(boolean) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Records statistics for get operations.
- recordGetStatistics(boolean) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
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.internal.util.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.internal.util.StatisticsProvider
-
Records a cache load operation.
- recordLoadFailure() - Method in class io.github.dhruv1110.jcachex.CacheStats
- recordMemoryRemoval(long) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- recordMemoryUsage(long) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- recordMiss() - Method in class io.github.dhruv1110.jcachex.CacheStats
- recordMiss(AtomicLong, boolean) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Records a cache miss in a thread-safe manner.
- recordPutStatistics() - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Records statistics for put operations.
- recordPutStatistics() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
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.base.AbstractCacheBase
-
Records statistics for remove operations.
- recordRemoveStatistics(boolean) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Records statistics for remove operations.
- recordScheduledTask(ScheduledFuture<?>) - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Records a scheduled task for later cancellation when this cache is closed.
- recordStats() - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Enables statistics recording.
- recordStats(boolean) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
-
Sets whether statistics should be recorded for this cache.
- recordStats(boolean) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Enables or disables statistics recording.
- 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.
- refreshAfterWrite(Duration) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Sets the duration after which entries are automatically refreshed.
- refreshEntries() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Refresh entries that need refreshing.
- refreshStaleEntries() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Refreshes stale entries.
- register() - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Builds and registers the profile with the ProfileRegistry.
- register(CacheProfile<Object, Object>, ProfileRegistry.ProfileMetadata) - Static method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry
-
Registers a cache profile with the registry.
- 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.distributed.impl.AbstractDistributedCache
- 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.base.AbstractCacheBase
-
Template method for remove operation with common validation.
- remove(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- remove(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- 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.communication.AbstractCommunicationProtocol.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.base.AbstractCacheBase
- removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.WriteHeavyOptimizedCache
- removeAsync(K) - Method in class io.github.dhruv1110.jcachex.impl.ZeroCopyOptimizedCache
- removeFromRemoteNode(String, K) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- removeNode(String) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.ConsistentHashRing
- removeNodeDiscoveryListener(NodeDiscovery.NodeDiscoveryListener) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
- removeNodeDiscoveryListener(NodeDiscovery.NodeDiscoveryListener) - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Removes a listener for node discovery events.
- replicationFactor(int) - Method in interface io.github.dhruv1110.jcachex.distributed.DistributedCache.Builder
- replicationLag - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- requestClusterInfo(String) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- requestClusterInfo(String) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Request cluster information from a remote node.
- requestKeyMigration(String, Collection<K>) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- requestKeyMigration(String, Collection<K>) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Request key migration from a remote node during cluster rebalancing.
- REQUIRED - io.github.dhruv1110.jcachex.concurrent.RingBuffer.DrainStatus
- requiresAsyncOperations(boolean) - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
- requiresConsistency(boolean) - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.Builder
- requiresHighConcurrency() - Method in class io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics
-
Returns true if this workload requires high concurrency support.
- reset() - Method in class io.github.dhruv1110.jcachex.CacheStats
- reset() - Method in class io.github.dhruv1110.jcachex.OptimizedFrequencySketch
-
Reset all counters (periodic aging).
- resetCounters(AtomicLong...) - Static method in class io.github.dhruv1110.jcachex.internal.util.StatisticsProvider
-
Resets all statistics counters to zero.
- 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.
- running - Variable in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
S
- sampleSize() - Method in class io.github.dhruv1110.jcachex.FrequencySketch
-
Returns the current sample size.
- scheduleCleanup() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Schedule periodic cleanup of expired entries.
- scheduleCleanup() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Schedules cleanup operations for expired entries.
- scheduleEviction() - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Schedules eviction using the optimized strategy.
- scheduleOptimizationTasks() - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Schedules periodic optimization tasks.
- scheduler - Variable in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- scheduler - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- scheduleRefresh() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Schedule refresh operations for entries.
- scheduleRefresh() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Schedules refresh operations.
- scheduleRefresh() - Method in class io.github.dhruv1110.jcachex.impl.DefaultCache
-
Schedule refresh operations for entries that support refresh.
- SchedulerProvider - Class in io.github.dhruv1110.jcachex.internal.util
-
Provides a shared ScheduledExecutorService for all caches to avoid creating per-cache scheduler threads.
- 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.
- sendGet(String, K) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- sendGet(String, K) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Send a GET request to retrieve a value from a remote node.
- sendHealthCheck(String) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- sendHealthCheck(String) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Send a health check request to a remote node.
- sendPut(String, K, V) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- sendPut(String, K, V) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Send a PUT request to store a key-value pair on a remote node.
- sendRemove(String, K) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- sendRemove(String, K) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Send a REMOVE request to delete a key from a remote node.
- sendRequest(String, AbstractCommunicationProtocol.CacheOperationRequest) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
-
Send a request to a remote node using the specific transport protocol.
- sendRequest(String, AbstractCommunicationProtocol.CacheOperationRequest) - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol
- SEQUENTIAL - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.AccessPattern
-
Sequential access pattern - good for prefetching
- serializationFailure(Object, Throwable) - Static method in exception io.github.dhruv1110.jcachex.exceptions.CacheOperationException
-
Creates an operation exception for serialization failures.
- serializeObject(Object) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- SESSION - io.github.dhruv1110.jcachex.profiles.ProfileTag
- SESSION_CACHE - io.github.dhruv1110.jcachex.profiles.ProfileName
- setCache(Cache<K, V>) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.InternalCacheHandler
- setLatency(Duration) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationResponse
- setLocalCache(Cache<K, V>) - Method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol
- setLocalCache(Cache<K, V>) - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Set the local cache instance for handling incoming requests.
- setValue(V) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase.ImmutableMapEntry
- setValue(V) - Method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations.ImmutableMapEntry
- shouldAvoidEvictingNewEntries() - Method in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
-
Determines if we should avoid evicting newly added entries.
- shouldAvoidEvictingNewEntries() - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Determines if we should avoid evicting newly added entries.
- 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.base.ConcurrentCacheBase
-
Shutdown the cache and clean up resources.
- shutdown() - Method in class io.github.dhruv1110.jcachex.impl.base.OptimizedCacheBase
-
Shuts down the optimized cache and cleans up resources.
- shutdown() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Shuts down the cache and cleans up resources.
- shutdown() - Method in class io.github.dhruv1110.jcachex.impl.MLOptimizedCache
- 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.base.OptimizedCacheBase.State
- SIMD - io.github.dhruv1110.jcachex.profiles.ProfileTag
- SINGLE_THREADED - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.ConcurrencyLevel
-
Single-threaded access
- 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.base.ConcurrentCacheBase
- size() - Method in class io.github.dhruv1110.jcachex.impl.base.DataBackedCacheBase
-
Common implementation of size() method.
- size() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- size() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- 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.
- SIZE_LARGE - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Large cache size for high-capacity scenarios.
- SIZE_MEDIUM - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Medium cache size for general use.
- SIZE_SMALL - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Small cache size for memory-constrained environments.
- SIZE_XLARGE - Static variable in class io.github.dhruv1110.jcachex.profiles.ProfileConstants
-
Extra large cache size for enterprise scenarios.
- snapshot() - Method in class io.github.dhruv1110.jcachex.CacheStats
- softValues(boolean) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
-
Configures the cache to store values using soft references.
- SPATIAL_LOCALITY - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.AccessPattern
-
Spatial locality - nearby items accessed together
- SPECIALIZED - io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Specialized profiles for specific scenarios.
- start() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
- start() - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Starts the node discovery service.
- startServer() - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Start the communication protocol server to listen for incoming requests.
- startServer() - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol
- StatisticsProvider - Class in io.github.dhruv1110.jcachex.internal.util
-
Utility class for common statistics handling patterns.
- stats - Variable in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
- stats - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- stats() - Method in interface io.github.dhruv1110.jcachex.Cache
-
Returns the cache statistics.
- stats() - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Common implementation of stats() method.
- stats() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- stats() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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.UltraFastCache
- 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.base.AbstractCacheBase
- statsEnabled - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- stop() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.KubernetesNodeDiscovery
- stop() - Method in interface io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery
-
Stops the node discovery service.
- stopServer() - Method in interface io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol
-
Stop the communication protocol server.
- stopServer() - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol
- STRIPE_COUNT - Static variable in class io.github.dhruv1110.jcachex.impl.base.ConcurrentCacheBase
- STRIPE_COUNT - Static variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- 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.base.ConcurrentCacheBase
- stripes - Variable in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
- success(byte[]) - Static method in class io.github.dhruv1110.jcachex.distributed.communication.AbstractCommunicationProtocol.CacheOperationResponse
- success(T, Duration) - Static method in class io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.CommunicationResult
- suitableFor(Predicate<WorkloadCharacteristics>) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets the suitability test for automatic profile selection.
T
- tags(ProfileTag...) - Method in class io.github.dhruv1110.jcachex.profiles.CacheProfileBuilder
-
Sets tags for the profile.
- tags(String...) - Method in class io.github.dhruv1110.jcachex.profiles.ProfileRegistry.ProfileMetadata.Builder
- TCP - io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolType
- TcpCommunicationProtocol<K,V> - Class in io.github.dhruv1110.jcachex.distributed.communication
-
TCP-based implementation of the CommunicationProtocol interface.
- TcpCommunicationProtocol(CommunicationProtocol.ProtocolConfig) - Constructor for class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol
- TcpCommunicationProtocol.Builder<K,V> - Class in io.github.dhruv1110.jcachex.distributed.communication
-
Builder for TcpCommunicationProtocol.
- TEMPORAL - io.github.dhruv1110.jcachex.profiles.ProfileTag
- TEMPORAL_LOCALITY - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.AccessPattern
-
Temporal locality - recent items accessed again soon
- THREAD_SAFE - io.github.dhruv1110.jcachex.profiles.ProfileTag
- THROUGHPUT - io.github.dhruv1110.jcachex.profiles.ProfileTag
- timeout(long) - Method in class io.github.dhruv1110.jcachex.distributed.communication.TcpCommunicationProtocol.Builder
- TIMEOUT - io.github.dhruv1110.jcachex.exceptions.CacheException.ErrorType
-
Timeout or performance errors
- 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).
- topologyVersion - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache
- toString() - Method in class io.github.dhruv1110.jcachex.CacheStats
- toString() - Method in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
- toString() - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveredNode
- toString() - Method in exception io.github.dhruv1110.jcachex.exceptions.CacheException
-
Returns a comprehensive string representation of this exception.
- toString() - Method in class io.github.dhruv1110.jcachex.internal.util.CacheCommonOperations.ImmutableMapEntry
- toString() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
- toString() - Method in enum io.github.dhruv1110.jcachex.profiles.ProfileTag
- toStringArray(ProfileTag...) - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileTag
-
Converts an array of ProfileTags to an array of their string values.
- 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.
- triggerEviction() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Triggers eviction when size limit is reached.
- TTL - io.github.dhruv1110.jcachex.profiles.ProfileTag
- type - Variable in class io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessRecord
U
- ULTRA_LOW_LATENCY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- UltraFastCache<K,V> - Class in io.github.dhruv1110.jcachex.impl
-
Ultra-fast cache implementation optimized for maximum throughput.
- UltraFastCache(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.UltraFastCache
- UNHEALTHY - io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.NodeHealth
- UnifiedCacheBase<K,V> - Class in io.github.dhruv1110.jcachex.impl.base
-
Unified base class for all cache implementations providing comprehensive functionality.
- UnifiedCacheBase(CacheConfig<K, V>) - Constructor for class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Constructor for all cache implementations.
- UnifiedCacheBase.ImmutableMapEntry<K,V> - Class in io.github.dhruv1110.jcachex.impl.base
-
Immutable map entry for collection views.
- UNKNOWN - io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.NodeHealth
- 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.base.AbstractCacheBase
-
Updates the stats object from the atomic counters.
- updateStatsFromCounters() - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Updates statistics from internal counters.
- useServiceAccount - Variable in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
- useServiceAccount(boolean) - Method in class io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.KubernetesDiscoveryBuilder
V
- validateConfiguration(CacheConfig<?, ?>) - Static method in class io.github.dhruv1110.jcachex.internal.util.ConfigurationProvider
-
Validates cache configuration parameters and throws appropriate exceptions.
- validateConfiguration(CacheConfig<K, V>) - Method in interface io.github.dhruv1110.jcachex.profiles.CacheProfile
-
Validates that the provided configuration is compatible with this profile.
- validateKey(K) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Validates that a key is not null.
- validateKey(K) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Validates that a key is not null.
- validateValue(V) - Method in class io.github.dhruv1110.jcachex.impl.base.AbstractCacheBase
-
Validates that a value is not null.
- validateValue(V) - Method in class io.github.dhruv1110.jcachex.impl.base.UnifiedCacheBase
-
Validates that a value is acceptable.
- 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.communication.AbstractCommunicationProtocol.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.communication.CommunicationProtocol.ProtocolType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.DiscoveryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.distributed.discovery.NodeDiscovery.NodeHealth
-
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.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.base.OptimizedCacheBase.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileCategory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.profiles.ProfileTag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.AccessPattern
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.ConcurrencyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.MemoryConstraint
-
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.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.communication.AbstractCommunicationProtocol.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.communication.CommunicationProtocol.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.discovery.NodeDiscovery.DiscoveryType
-
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.discovery.NodeDiscovery.NodeHealth
-
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.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.base.DataBackedCacheBase
-
Common implementation of values() method with filtering.
- values() - Static method in enum io.github.dhruv1110.jcachex.impl.base.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.base.UnifiedCacheBase
- values() - Method in class io.github.dhruv1110.jcachex.impl.CacheLocalityOptimizedCache
- 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() - 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.UltraFastCache
- 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.profiles.ProfileCategory
-
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.profiles.ProfileName
-
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.profiles.ProfileTag
-
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.profiles.WorkloadCharacteristics.AccessPattern
-
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.profiles.WorkloadCharacteristics.ConcurrencyLevel
-
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.profiles.WorkloadCharacteristics.MemoryConstraint
-
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.base.OptimizedCacheBase
- VERY_HIGH - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.ConcurrencyLevel
-
Very high concurrency - extreme thread contention
- VERY_LIMITED - io.github.dhruv1110.jcachex.profiles.WorkloadCharacteristics.MemoryConstraint
-
Very limited memory - optimize for minimal allocation
- virtualNodesPerNode - Variable in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
- virtualNodesPerNode(int) - Method in class io.github.dhruv1110.jcachex.distributed.impl.AbstractDistributedCache.Builder
W
- warmUp(Set<K>) - Method in class io.github.dhruv1110.jcachex.impl.ReadOnlyOptimizedCache
-
Warm up the cache by pre-loading frequently accessed data.
- weakKeys(boolean) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
-
Configures the cache to store keys using weak references.
- weakValues(boolean) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
-
Configures the cache to store values using weak references.
- weigher(BiFunction<K, V, Long>) - Method in class io.github.dhruv1110.jcachex.CacheConfig.Builder
-
Sets the weigher function used to calculate entry weights.
- weigher(BiFunction<K, V, Long>) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Sets the weigher function for calculating 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.base.OptimizedCacheBase
- withSmartDefaults() - Static method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Creates a new builder that will automatically select the optimal profile based on workload characteristics.
- workloadCharacteristics(WorkloadCharacteristics) - Method in class io.github.dhruv1110.jcachex.JCacheXBuilder
-
Sets the workload characteristics for smart profile selection.
- WorkloadCharacteristics - Class in io.github.dhruv1110.jcachex.profiles
-
Encapsulates workload characteristics for cache profiling and optimization.
- WorkloadCharacteristics.AccessPattern - Enum in io.github.dhruv1110.jcachex.profiles
-
Enum representing different access patterns.
- WorkloadCharacteristics.Builder - Class in io.github.dhruv1110.jcachex.profiles
-
Builder for WorkloadCharacteristics.
- WorkloadCharacteristics.ConcurrencyLevel - Enum in io.github.dhruv1110.jcachex.profiles
-
Enum representing concurrency characteristics.
- WorkloadCharacteristics.MemoryConstraint - Enum in io.github.dhruv1110.jcachex.profiles
-
Enum representing memory constraints.
- WRITE - io.github.dhruv1110.jcachex.concurrent.AccessBuffer.AccessType
- WRITE_HEAVY - io.github.dhruv1110.jcachex.profiles.ProfileName
- WRITE_HEAVY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- 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 - io.github.dhruv1110.jcachex.profiles.ProfileName
- ZERO_COPY - io.github.dhruv1110.jcachex.profiles.ProfileTag
- 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
All Classes All Packages