A B C D E F G H I J K L M N O P Q R S T U V W
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abort() - Method in class org.cache2k.core.EntryAction
-
Abort, but check whether entry was locked before.
- ABORTED - Static variable in class org.cache2k.core.Entry
- abortFinalize() - Method in class org.cache2k.core.EntryAction
- abortReleaseLock() - Method in class org.cache2k.core.EntryAction
-
Release the lock.
- AbortWhenProcessingException() - Constructor for exception org.cache2k.core.EntryAction.AbortWhenProcessingException
- AbstractCacheEntry<K,V> - Class in org.cache2k.core
-
Abstract class for cache entry providing suitable defaults.
- AbstractCacheEntry() - Constructor for class org.cache2k.core.AbstractCacheEntry
- AbstractCacheStatistics - Class in org.cache2k.core.common
-
Extract statistics from
InternalCacheInfo
- AbstractCacheStatistics() - Constructor for class org.cache2k.core.common.AbstractCacheStatistics
- AbstractEviction - Class in org.cache2k.core.eviction
-
Base class for different eviction algorithms, implementing statistics counting and chunking.
- AbstractEviction(HeapCacheForEviction, InternalEvictionListener, long, Weigher, long, boolean) - Constructor for class org.cache2k.core.eviction.AbstractEviction
- action() - Method in class org.cache2k.core.timing.TimerTask
-
The action to be performed by this timer task.
- asMap() - Method in class org.cache2k.core.BaseCache
- AsyncDispatcher<K> - Class in org.cache2k.core.event
-
Dispatch events via the executor.
- AsyncDispatcher(InternalCache<?, ?>, Executor) - Constructor for class org.cache2k.core.event.AsyncDispatcher
- AsyncEvent<K> - Class in org.cache2k.core.event
- AsyncEvent() - Constructor for class org.cache2k.core.event.AsyncEvent
- asyncLoader() - Method in class org.cache2k.core.EntryAction
- augmentConfig(CacheManager, Cache2kConfig<K, V>) - Method in class org.cache2k.core.DummyConfigProvider
- augmentConfig(CacheManager, Cache2kConfig<K, V>) - Method in interface org.cache2k.core.spi.CacheConfigProvider
-
Called when
Cache2kBuilder.build()
was called before the configuration is used to create the cache.
B
- Base() - Constructor for class org.cache2k.core.operation.Semantic.Base
- BaseCache<K,V> - Class in org.cache2k.core
-
Some default implementations for a cache.
- BaseCache() - Constructor for class org.cache2k.core.BaseCache
- BaseCacheControl - Class in org.cache2k.core.common
-
Provide cache control on top of internal cache.
- BaseCacheControl(InternalCache<?, ?>) - Constructor for class org.cache2k.core.common.BaseCacheControl
- BlackHole() - Constructor for class org.cache2k.core.api.CommonMetrics.BlackHole
- build() - Method in class org.cache2k.core.InternalCache2kBuilder
- builder() - Method in class org.cache2k.core.api.InternalConfig
- Builder(InternalConfig) - Constructor for class org.cache2k.core.api.InternalConfig.Builder
- buildWithoutExternalConfig() - Method in class org.cache2k.core.InternalCache2kBuilder
-
Build without applying external configuration.
- BulkAction<K,V,R> - Class in org.cache2k.core
-
Execute a set of entry actions in parallel to leverage bulk I/O.
- BulkAction(HeapCache<K, V>, InternalCache<K, V>, AsyncCacheLoader<K, V>, Set<K>) - Constructor for class org.cache2k.core.BulkAction
-
Create object and start operation.
- bulkOperationCompleted() - Method in class org.cache2k.core.BulkAction
- BulkOperationException - Exception in org.cache2k.core
- BulkOperationException(int, int, Throwable) - Constructor for exception org.cache2k.core.BulkOperationException
- BulkResultCollector<K,V> - Class in org.cache2k.core
-
Collects result values of a bulk operation.
- BulkResultCollector() - Constructor for class org.cache2k.core.BulkResultCollector
C
- CACHE_CONFIGURATION_PROVIDER - Static variable in class org.cache2k.core.Cache2kCoreProviderImpl
- Cache2kCoreProviderImpl - Class in org.cache2k.core
- Cache2kCoreProviderImpl() - Constructor for class org.cache2k.core.Cache2kCoreProviderImpl
- Cache2kVersion - Class in org.cache2k.core.util
-
Static helper class to provide the cache2k version.
- Cache2kVersion() - Constructor for class org.cache2k.core.util.Cache2kVersion
- cacheClosed(Cache<?, ?>) - Method in class org.cache2k.core.CacheManagerImpl
-
Called from the cache during close()
- cacheClosed(Cache<K, V>, InternalCacheCloseContext) - Method in interface org.cache2k.core.spi.CacheLifeCycleListener
- CacheClosedException - Exception in org.cache2k.core
-
Consistently this exception is thrown, when an operation detects that the cache is closed.
- CacheClosedException() - Constructor for exception org.cache2k.core.CacheClosedException
- CacheClosedException(String) - Constructor for exception org.cache2k.core.CacheClosedException
-
Included manager and cache name in the detail message, preferred.
- CacheClosedException(InternalCache<?, ?>) - Constructor for exception org.cache2k.core.CacheClosedException
- CacheConfigProvider - Interface in org.cache2k.core.spi
-
Plugin interface for the configuration system.
- cacheCreated(Cache<K, V>, InternalCacheBuildContext<K, V>) - Method in interface org.cache2k.core.spi.CacheLifeCycleListener
- cacheDisabledExpireImmediately() - Method in class org.cache2k.core.EntryAction
- cacheExceptionUntil(Entry<K, V>, LoadExceptionInfo) - Method in class org.cache2k.core.timing.StaticTiming
- cacheExceptionUntil(Entry<K, V>, LoadExceptionInfo) - Method in class org.cache2k.core.timing.Timing
-
Delegated to the resilience policy
- CacheInternalError - Error in org.cache2k.core
-
An internal error condition in the cache was detected that actually never is supposed to happen.
- CacheInternalError(String) - Constructor for error org.cache2k.core.CacheInternalError
- CacheInternalError(String, Throwable) - Constructor for error org.cache2k.core.CacheInternalError
- CacheLifeCycleListener - Interface in org.cache2k.core.spi
-
Interface to implement additional service providers that get notified on a lifecycle change of the cache.
- CacheManagerImpl - Class in org.cache2k.core
- CacheManagerImpl(Cache2kCoreProviderImpl, ClassLoader, String, boolean) - Constructor for class org.cache2k.core.CacheManagerImpl
- CacheManagerLifeCycleListener - Interface in org.cache2k.core.spi
-
Service provider interface to hook in manager extensions.
- CacheOperationInterruptedException - Exception in org.cache2k.core
-
Used to rethrow if we get an
InterruptedException
- CacheOperationInterruptedException(InterruptedException) - Constructor for exception org.cache2k.core.CacheOperationInterruptedException
- calcEntryCount() - Method in class org.cache2k.core.StampedHash
-
Count the entries in the hash table, by scanning through the hash table.
- calculateNextRefreshTime(Entry<K, V>, V, long) - Method in class org.cache2k.core.timing.StaticTiming
- calculateNextRefreshTime(Entry<K, V>, V, long) - Method in class org.cache2k.core.timing.Timing
-
Calculates the expiry time for a value that was just loaded or inserted into the cache.
- callListeners() - Method in class org.cache2k.core.EntryAction
- cancel() - Method in class org.cache2k.core.timing.TimerTask
-
Not thread save to use directly, use
Timer.cancel(TimerTask)
It can happen that cancel is called on a task that is already executing - cancel(TimerTask) - Method in class org.cache2k.core.timing.DefaultTimer
- cancel(TimerTask) - Method in interface org.cache2k.core.timing.Timer
-
Cancel the timer task.
- cancelAll() - Method in class org.cache2k.core.timing.DefaultTimer
-
Terminates all timer tasks current pending.
- cancelAll() - Method in class org.cache2k.core.timing.StaticTiming
- cancelAll() - Method in interface org.cache2k.core.timing.Timer
-
Terminates all timer tasks currently pending.
- cancelAll() - Method in interface org.cache2k.core.timing.TimerStructure
-
Cancel all tasks
- cancelAll() - Method in class org.cache2k.core.timing.TimerWheels
- cancelAll() - Method in class org.cache2k.core.timing.Timing
-
Cancels all pending timer events.
- cancelExpiryTimer(Entry<K, V>) - Method in class org.cache2k.core.timing.StaticTiming
- cancelExpiryTimer(Entry<K, V>) - Method in class org.cache2k.core.timing.Timing
-
Cancel the timer on the entry, if a timer was set.
- cancelTimerJobs() - Method in interface org.cache2k.core.api.InternalCache
-
used from the cache manager for shutdown
- cancelTimerJobs() - Method in class org.cache2k.core.HeapCache
-
Preparation for shutdown.
- cancelTimerJobs() - Method in class org.cache2k.core.WiredCache
- changeCapacity(long) - Method in class org.cache2k.core.common.BaseCacheControl
-
Change the capacity.
- changeCapacity(long) - Method in class org.cache2k.core.eviction.AbstractEviction
-
Update the limits and run eviction loop with chunks to get rid of entries fast.
- changeCapacity(long) - Method in class org.cache2k.core.eviction.DelegatingEviction
- changeCapacity(long) - Method in interface org.cache2k.core.eviction.Eviction
-
Change the capacity.
- changeCapacity(long) - Method in class org.cache2k.core.SegmentedEviction
- check(String, boolean) - Method in class org.cache2k.core.IntegrityState
- check(String, String, boolean) - Method in class org.cache2k.core.IntegrityState
- checkAllPresent(Iterable<? extends K>) - Method in class org.cache2k.core.HeapCache
-
Checks for entries being present and fresh.
- checkAndSwitchProcessingState(int, int) - Method in class org.cache2k.core.Entry
-
Check and switch the processing state atomically.
- checkClosed() - Method in class org.cache2k.core.HeapCache
- checkCyclicListIntegrity(Entry) - Static method in class org.cache2k.core.Entry
- checkEquals(String, int, int) - Method in class org.cache2k.core.IntegrityState
- checkEquals(String, long, long) - Method in class org.cache2k.core.IntegrityState
- checkExpand(int) - Method in class org.cache2k.core.StampedHash
-
Checks whether expansion is needed and expand when
StampedHash.insertWithinLock(Entry, int, int)
is used. - checkExpiryBeforeMutation() - Method in class org.cache2k.core.EntryAction
-
Check whether we are executed on an expired entry before the timer event for the expiry was received.
- checkGreater(String, int, int) - Method in class org.cache2k.core.IntegrityState
- checkGreaterOrEquals(String, int, int) - Method in class org.cache2k.core.IntegrityState
- checkIntegrity() - Method in interface org.cache2k.core.api.InternalCache
-
Cache checks its internal integrity.
- checkIntegrity() - Method in class org.cache2k.core.HeapCache
-
Check internal data structures and throw and exception if something is wrong, used for unit testing
- checkIntegrity() - Method in class org.cache2k.core.WiredCache
- checkIntegrity(IntegrityState) - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- checkIntegrity(IntegrityState) - Method in class org.cache2k.core.eviction.DelegatingEviction
- checkIntegrity(IntegrityState) - Method in interface org.cache2k.core.eviction.Eviction
- checkIntegrity(IntegrityState) - Method in class org.cache2k.core.SegmentedEviction
- checkKeepOrRemove() - Method in class org.cache2k.core.EntryAction
-
In case we have an expiry of 0, this means that the entry should not be cached.
- checkLess(String, int, int) - Method in class org.cache2k.core.IntegrityState
- checkLessOrEquals(String, int, int) - Method in class org.cache2k.core.IntegrityState
- checkName(String) - Static method in class org.cache2k.core.CacheManagerImpl
-
Don't accept a cache or manager names with too weird characters.
- clear() - Method in class org.cache2k.core.CacheManagerImpl
- clear() - Method in class org.cache2k.core.common.BaseCacheControl
- clear() - Method in class org.cache2k.core.ConcurrentMapWrapper
- clear() - Method in class org.cache2k.core.HeapCache
- clear() - Method in class org.cache2k.core.MapValueConverterProxy
- clear() - Method in class org.cache2k.core.WiredCache
- clearCnt - Variable in class org.cache2k.core.HeapCache
-
Number of clear operations.
- clearedTime - Variable in class org.cache2k.core.HeapCache
- clearLocalCache() - Method in class org.cache2k.core.HeapCache
- clearRemovedCnt - Variable in class org.cache2k.core.HeapCache
-
Number of entries removed by clear.
- clearWhenLocked() - Method in class org.cache2k.core.StampedHash
- clock - Variable in class org.cache2k.core.HeapCache
- clock - Variable in class org.cache2k.core.timing.StaticTiming
- ClockProPlusEviction - Class in org.cache2k.core.eviction
-
Eviction algorithm inspired from CLOCK Pro with 3 clocks.
- ClockProPlusEviction(HeapCacheForEviction, InternalEvictionListener, long, Weigher, long, boolean) - Constructor for class org.cache2k.core.eviction.ClockProPlusEviction
- close() - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- close() - Method in class org.cache2k.core.CacheManagerImpl
-
The shutdown takes place in two phases.
- close() - Method in class org.cache2k.core.common.BaseCacheControl
- close() - Method in class org.cache2k.core.HeapCache
- close() - Method in class org.cache2k.core.InternalCache2kBuilder.WrappedAdvancedCacheLoader
- close() - Method in class org.cache2k.core.StampedHash
-
Close the cache by discarding the entry table.
- close() - Method in class org.cache2k.core.WiredCache
- close(ClassLoader) - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- close(ClassLoader, String) - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- close(InternalCacheCloseContext) - Method in interface org.cache2k.core.api.NeedsClose
- close(InternalCacheCloseContext) - Method in class org.cache2k.core.eviction.AbstractEviction
- close(InternalCacheCloseContext) - Method in class org.cache2k.core.eviction.DelegatingEviction
- close(InternalCacheCloseContext) - Method in class org.cache2k.core.eviction.IdleScan
- close(InternalCacheCloseContext) - Method in class org.cache2k.core.eviction.IdleScanEviction
- close(InternalCacheCloseContext) - Method in class org.cache2k.core.SegmentedEviction
- close(InternalCacheCloseContext) - Method in class org.cache2k.core.timing.DefaultTimer
- close(InternalCacheCloseContext) - Method in class org.cache2k.core.timing.StaticTiming
- close(InternalCacheCloseContext) - Method in class org.cache2k.core.timing.Timing
- closeCustomization(Object, String) - Method in interface org.cache2k.core.api.InternalCacheCloseContext
-
Call close on the customization if the
AutoCloseable
interface is implemented - closeCustomization(Object, String) - Method in class org.cache2k.core.BaseCache
- closePart1() - Method in class org.cache2k.core.HeapCache
- closePart2(InternalCache) - Method in class org.cache2k.core.HeapCache
- CommonMetrics - Interface in org.cache2k.core.api
-
Statistic metrics common to every cache type.
- CommonMetrics.BlackHole - Class in org.cache2k.core.api
- CommonMetrics.Updater - Interface in org.cache2k.core.api
- compactFullName(CacheManager, String) - Static method in class org.cache2k.core.util.Util
- complete(K, Throwable) - Method in class org.cache2k.core.OperationCompletion
-
Notify that operation for one key has been completed.
- completeProcessCallbacks() - Method in class org.cache2k.core.EntryAction
-
Execute any callback or other actions waiting for this one to complete.
- compress(int) - Static method in class org.cache2k.core.IntegerTo16BitFloatingPoint
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.cache2k.core.ConcurrentMapWrapper
- COMPUTE - Static variable in class org.cache2k.core.Entry.ProcessingState
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.cache2k.core.ConcurrentMapWrapper
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.cache2k.core.HeapCache
-
Code duplicates with
Cache.get(Object)
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.cache2k.core.operation.Operations
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.cache2k.core.WiredCache
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.cache2k.core.ConcurrentMapWrapper
- ConcurrentEntryIterator<K,V> - Class in org.cache2k.core
-
Iterator over all cache entries.
- ConcurrentEntryIterator(HeapCache<K, V>) - Constructor for class org.cache2k.core.ConcurrentEntryIterator
- ConcurrentMapWrapper<K,V> - Class in org.cache2k.core
-
ConcurrentMap interface wrapper on top of a cache.
- ConcurrentMapWrapper(InternalCache<K, V>) - Constructor for class org.cache2k.core.ConcurrentMapWrapper
- config() - Method in class org.cache2k.core.api.InternalConfig.Builder
- constructEviction(InternalCacheBuildContext<?, ?>, HeapCacheForEviction, InternalEvictionListener, Cache2kConfig, int) - Method in class org.cache2k.core.eviction.EvictionFactory
-
Construct segmented or queued eviction.
- contains(K) - Method in class org.cache2k.core.operation.Operations
- containsAndRemove(K) - Method in class org.cache2k.core.HeapCache
- containsAndRemove(K) - Method in class org.cache2k.core.operation.Operations
- containsAndRemove(K) - Method in class org.cache2k.core.WiredCache
- containsKey(Object) - Method in class org.cache2k.core.ConcurrentMapWrapper
- containsKey(Object) - Method in class org.cache2k.core.MapValueConverterProxy
- containsKey(K) - Method in class org.cache2k.core.HeapCache
- containsKey(K) - Method in class org.cache2k.core.WiredCache
- containsValue(Object) - Method in class org.cache2k.core.ConcurrentMapWrapper
- containsValue(Object) - Method in class org.cache2k.core.MapValueConverterProxy
- continueWithMutation() - Method in class org.cache2k.core.EntryAction
- convert(S) - Method in class org.cache2k.core.MapValueConverterProxy
-
Only called when the value object is requested.
- convertCacheEntry2ValueMap(Map<K, CacheEntry<K, V>>) - Method in class org.cache2k.core.HeapCache
- convertValueMap(Map<K, Object>) - Method in class org.cache2k.core.HeapCache
- createBulkLoaderException(int, int, Throwable) - Static method in class org.cache2k.core.BulkResultCollector
- createCache(CacheManager, Cache2kConfig<K, V>) - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- createCache(Cache2kConfig<K, V>) - Method in class org.cache2k.core.CacheManagerImpl
- createCustomization(CustomizationSupplier<? extends T>, CustomizationSupplier<? extends T>) - Method in interface org.cache2k.core.api.InternalCacheBuildContext
- createCustomization(CustomizationSupplier<? extends T>, T) - Method in interface org.cache2k.core.api.InternalCacheBuildContext
-
Create the customization.
- createCustomization(CustomizationSupplier<T>) - Method in interface org.cache2k.core.api.InternalCacheBuildContext
-
Create the customization.
- createCustomization(CustomizationSupplier<T>) - Method in class org.cache2k.core.InternalCache2kBuilder
- createEntryAction(K, BulkAction<K, V, R>) - Method in class org.cache2k.core.BulkAction
- createEntryAction(K, Entry<K, V>, Semantic<K, V, R>) - Method in class org.cache2k.core.BaseCache
- createEntryAction(K, Entry<K, V>, Semantic<K, V, R>) - Method in class org.cache2k.core.HeapCache
- createEntryAction(K, Entry<K, V>, Semantic<K, V, R>) - Method in class org.cache2k.core.WiredCache
- createFireAndForgetAction(Entry<K, V>, Semantic<K, V, R>) - Method in class org.cache2k.core.BaseCache
- createFireAndForgetAction(Entry<K, V>, Semantic<K, V, R>) - Method in class org.cache2k.core.HeapCache
- createFireAndForgetAction(Entry<K, V>, Semantic<K, V, R>) - Method in class org.cache2k.core.WiredCache
- createHashTable() - Method in class org.cache2k.core.HeapCache
- createHashTable() - Method in class org.cache2k.core.IntHeapCache
-
Modified hash table implementation.
- createScheduler() - Method in interface org.cache2k.core.api.InternalCacheBuildContext
-
Create a new scheduler instance which must be closed.
- createScheduler() - Method in class org.cache2k.core.InternalCache2kBuilder
D
- DATA_VALID - Static variable in class org.cache2k.core.Entry
-
bigger or equal means entry has / contains valid data
- debug(String) - Method in class org.cache2k.core.log.Log
- debug(String) - Method in class org.cache2k.core.log.Log.JdkLogger
-
Send the log message to the JDK logger.
- debug(String) - Method in class org.cache2k.core.log.Log.Slf4jLogger
- debug(String) - Method in class org.cache2k.core.log.Log.SuppressionCounter
- debug(String, Throwable) - Method in class org.cache2k.core.log.Log
- debug(String, Throwable) - Method in class org.cache2k.core.log.Log.JdkLogger
- debug(String, Throwable) - Method in class org.cache2k.core.log.Log.Slf4jLogger
- debug(String, Throwable) - Method in class org.cache2k.core.log.Log.SuppressionCounter
- DEFAULT - Static variable in interface org.cache2k.core.concurrency.ThreadFactoryProvider
- DEFAULT_SLOTS_PER_WHEEL - Static variable in class org.cache2k.core.timing.DefaultTimer
-
Expecting that expiry values between 0 and 15 minutes are very common, we cover these on the first level.
- DEFAULT_TIMER_LAG_MILLIS - Static variable in class org.cache2k.core.timing.DefaultTimer
-
Default for timer lag in milliseconds
- DefaultExceptionPropagator<K,V> - Class in org.cache2k.core
-
Standard behavior of the exception propagator.
- DefaultSchedulerProvider - Class in org.cache2k.core.timing
-
Provides scheduler instances for caches which are backed by a common
ScheduledThreadPoolExecutor
and two threads. - DefaultThreadFactoryProvider - Class in org.cache2k.core.concurrency
-
Provide the default implementation for the thread factory.
- DefaultThreadFactoryProvider() - Constructor for class org.cache2k.core.concurrency.DefaultThreadFactoryProvider
- DefaultTimer - Class in org.cache2k.core.timing
-
Standard timer implementation.
- DefaultTimer(TimeReference, Scheduler) - Constructor for class org.cache2k.core.timing.DefaultTimer
- DefaultTimer(TimeReference, Scheduler, long) - Constructor for class org.cache2k.core.timing.DefaultTimer
- DefaultTimer(TimeReference, Scheduler, long, int) - Constructor for class org.cache2k.core.timing.DefaultTimer
- delegate() - Method in class org.cache2k.core.eviction.DelegatingEviction
- delegate() - Method in class org.cache2k.core.eviction.IdleScanEviction
- DelegatingEviction - Class in org.cache2k.core.eviction
-
Delegates all eviction interaction.
- DelegatingEviction() - Constructor for class org.cache2k.core.eviction.DelegatingEviction
- deregisterSuppression(String) - Static method in class org.cache2k.core.log.Log
- destroy() - Method in class org.cache2k.core.common.BaseCacheControl
- determineMaxSize(long, int) - Static method in class org.cache2k.core.eviction.EvictionFactory
- determineMaxWeight(long, int) - Static method in class org.cache2k.core.eviction.EvictionFactory
- determineSegmentCount(boolean, int, boolean, long, long, int) - Static method in class org.cache2k.core.eviction.EvictionFactory
-
Determine number of segments based on the the available processors.
- DONE - Static variable in class org.cache2k.core.Entry.ProcessingState
- DummyConfigProvider - Class in org.cache2k.core
-
The configuration via XML can be removed (e.g.
- DummyConfigProvider() - Constructor for class org.cache2k.core.DummyConfigProvider
E
- enqueueToExecute(EntryAction) - Method in class org.cache2k.core.EntryAction
-
Called on the processing action to enqueue another action to be executed next.
- ensureAbort(boolean) - Method in class org.cache2k.core.Entry
-
Make sure entry processing is properly finished, otherwise threads waiting for an entry get stuck.
- entries() - Method in class org.cache2k.core.BaseCache
- Entry<K,V> - Class in org.cache2k.core
-
The cache entry.
- Entry() - Constructor for class org.cache2k.core.Entry
- Entry(K, int) - Constructor for class org.cache2k.core.Entry
- Entry.ProcessingState - Class in org.cache2k.core
-
Different possible processing states.
- EntryAction<K,V,R> - Class in org.cache2k.core
-
This is a method object to perform an operation on an entry.
- EntryAction(HeapCache<K, V>, InternalCache<K, V>, Semantic<K, V, R>, K, Entry<K, V>) - Constructor for class org.cache2k.core.EntryAction
- EntryAction(HeapCache<K, V>, InternalCache<K, V>, Semantic<K, V, R>, K, Entry<K, V>, EntryAction.CompletedCallback<K, V, R>) - Constructor for class org.cache2k.core.EntryAction
- EntryAction.AbortWhenProcessingException - Exception in org.cache2k.core
- EntryAction.CompletedCallback<K,V,R> - Interface in org.cache2k.core
- EntryAction.ListenerException - Exception in org.cache2k.core
- entryActionCompleted(EntryAction<K, V, R>) - Method in class org.cache2k.core.BulkAction
-
Callback upon completion of an entry action.
- entryActionCompleted(EntryAction<K, V, R>) - Method in interface org.cache2k.core.EntryAction.CompletedCallback
- entryCreatedListeners() - Method in class org.cache2k.core.EntryAction
-
Provide the registered listeners for entry creation.
- entryExpiredListeners() - Method in class org.cache2k.core.EntryAction
- EntryProcessingResultFactory - Class in org.cache2k.core
- EntryProcessingResultFactory() - Constructor for class org.cache2k.core.EntryProcessingResultFactory
- entryRemovedListeners() - Method in class org.cache2k.core.EntryAction
-
Provide the registered listeners for entry removal.
- entryResult(ExaminationEntry<K, V>) - Method in class org.cache2k.core.EntryAction
- entryResult(ExaminationEntry<K, V>) - Method in interface org.cache2k.core.operation.Progress
-
Returns a cache entry as result.
- entrySet() - Method in class org.cache2k.core.ConcurrentMapWrapper
- entrySet() - Method in class org.cache2k.core.MapValueConverterProxy
- entryUpdatedListeners() - Method in class org.cache2k.core.EntryAction
-
Provide the registered listeners for entry update.
- ETERNAL - Static variable in class org.cache2k.core.timing.TimeAgnosticTiming
-
Used as default
- ETERNAL_IMMEDIATE - Static variable in class org.cache2k.core.timing.TimeAgnosticTiming
- EventCounter - Interface in org.cache2k.core
- EVICT - Static variable in class org.cache2k.core.Entry.ProcessingState
- evictEventually() - Method in class org.cache2k.core.eviction.AbstractEviction
- evictEventually() - Method in class org.cache2k.core.eviction.DelegatingEviction
- evictEventually() - Method in interface org.cache2k.core.eviction.Eviction
-
Evict if needed, checks all segments.
- evictEventually() - Method in class org.cache2k.core.SegmentedEviction
- evictEventuallyBeforeInsert() - Method in class org.cache2k.core.eviction.AbstractEviction
- evictEventuallyBeforeInsert() - Method in class org.cache2k.core.eviction.DelegatingEviction
- evictEventuallyBeforeInsert() - Method in interface org.cache2k.core.eviction.Eviction
-
Evict if needed, checks all segments.
- evictEventuallyBeforeInsert() - Method in class org.cache2k.core.SegmentedEviction
- evictEventuallyBeforeInsertOnSegment(int) - Method in class org.cache2k.core.eviction.AbstractEviction
- evictEventuallyBeforeInsertOnSegment(int) - Method in class org.cache2k.core.eviction.DelegatingEviction
- evictEventuallyBeforeInsertOnSegment(int) - Method in interface org.cache2k.core.eviction.Eviction
-
Evict if needed, focused on the segment addressed by the hash code.
- evictEventuallyBeforeInsertOnSegment(int) - Method in class org.cache2k.core.SegmentedEviction
- evictIdleEntries(int) - Method in class org.cache2k.core.eviction.AbstractEviction
- evictIdleEntries(int) - Method in class org.cache2k.core.eviction.DelegatingEviction
- evictIdleEntries(int) - Method in interface org.cache2k.core.eviction.Eviction
-
Scan for idle (no access count since last scan) entries and evict them.
- evictIdleEntries(int) - Method in class org.cache2k.core.SegmentedEviction
-
Scan all segments for idlers.
- Eviction - Interface in org.cache2k.core.eviction
-
Interface to the eviction data structure.
- EvictionFactory - Class in org.cache2k.core.eviction
- EvictionFactory() - Constructor for class org.cache2k.core.eviction.EvictionFactory
- EvictionMetrics - Interface in org.cache2k.core.eviction
-
Access to eviction metrics.
- examinationAbort(CustomizationException) - Method in class org.cache2k.core.EntryAction
- ExaminationEntry<K,V> - Interface in org.cache2k.core.operation
-
A entry on the heap cache, used for reading.
- examine() - Method in class org.cache2k.core.EntryAction
- examine(K, Progress<K, V, Void>, ExaminationEntry<K, V>) - Method in class org.cache2k.core.operation.Operations.ExpireEvent
- examine(K, Progress<K, V, R>, ExaminationEntry<K, V>) - Method in interface org.cache2k.core.operation.Semantic
-
Called with the entry containing the recent content.
- examine(K, Progress<K, V, R>, ExaminationEntry<K, V>) - Method in class org.cache2k.core.operation.Semantic.InsertOrUpdate
-
Instruct to lock the entry for the update.
- examine(K, Progress<K, V, R>, ExaminationEntry<K, V>) - Method in class org.cache2k.core.operation.Semantic.Update
-
Unconditionally request mutation lock.
- exception(Throwable) - Static method in class org.cache2k.core.EntryProcessingResultFactory
- exceptionPropagator - Variable in class org.cache2k.core.HeapCache
- ExceptionWrapper<K,V> - Class in org.cache2k.core
-
The exception wrapper is used in the value field of the entry, in case of an exception.
- ExceptionWrapper(K, long, Throwable, ExceptionPropagator<K, V>) - Constructor for class org.cache2k.core.ExceptionWrapper
- ExceptionWrapper(K, Throwable, long, Entry, ExceptionPropagator<K, V>) - Constructor for class org.cache2k.core.ExceptionWrapper
-
Take over exception information from the entry, which either has no exception, an existing cached exception or a suppressed exception.
- ExceptionWrapper(K, Throwable, long, LoadExceptionInfo, ExceptionPropagator<K, V>) - Constructor for class org.cache2k.core.ExceptionWrapper
- ExceptionWrapper(ExceptionWrapper<K, V>, long) - Constructor for class org.cache2k.core.ExceptionWrapper
-
Copy constructor to set until.
- execute() - Method in class org.cache2k.core.event.AsyncEvent
- execute(K, Entry<K, V>, Semantic<K, V, R>) - Method in class org.cache2k.core.BaseCache
- execute(K, Semantic<K, V, R>) - Method in class org.cache2k.core.BaseCache
- executeLoader(Runnable) - Method in class org.cache2k.core.HeapCache
-
Execute with loader executor and back pressure.
- executeWithGlobalLock(Supplier<T>) - Method in class org.cache2k.core.HeapCache
-
Execute job while making sure that no other operations are going on.
- executor() - Method in class org.cache2k.core.EntryAction
- existingEntryExpiredBeforeMutationSendExpiryEvents() - Method in class org.cache2k.core.EntryAction
-
The entry logically expired before the mutation.
- expand(int) - Static method in class org.cache2k.core.IntegerTo16BitFloatingPoint
- expectKey(K) - Method in class org.cache2k.core.BulkAction
- expire(long) - Method in class org.cache2k.core.EntryAction
- expire(long) - Method in interface org.cache2k.core.operation.Progress
-
Reset expiry to the specified value.
- expire(K, long) - Method in class org.cache2k.core.operation.Operations
- EXPIRE - Static variable in class org.cache2k.core.Entry.ProcessingState
- expireAt(K, long) - Method in class org.cache2k.core.BaseCache
- EXPIRED - Static variable in class org.cache2k.core.Entry
- EXPIRED_REFRESH_PENDING - Static variable in class org.cache2k.core.Entry
-
Expired, but protect entry from removal, since refresh is started.
- EXPIRED_REFRESHED - Static variable in class org.cache2k.core.Entry
-
Entry is in refresh probation phase
- expiredAtEndOfOperationStartOver() - Method in class org.cache2k.core.EntryAction
-
Entry expired during progress of the action, reenter at a previous processing state to call listeners and update heap.
- expiredImmediatelyAndRemove() - Method in class org.cache2k.core.EntryAction
- expiredImmediatelyKeepData() - Method in class org.cache2k.core.EntryAction
- expiredKept() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- expiredKept() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- expiredKept() - Method in class org.cache2k.core.StandardCommonMetrics
- expireEntry(Entry<K, V>) - Method in class org.cache2k.core.HeapCache
- expireEvent - Variable in class org.cache2k.core.operation.Operations
- ExpireEvent() - Constructor for class org.cache2k.core.operation.Operations.ExpireEvent
- EXPIRY - Static variable in class org.cache2k.core.Entry.ProcessingState
- EXPIRY_COMPLETE - Static variable in class org.cache2k.core.Entry.ProcessingState
- EXPIRY_TIME_MIN - Static variable in class org.cache2k.core.Entry
-
A value greater as this means it is a time value.
- expiryCalculated() - Method in class org.cache2k.core.EntryAction
- expiryCalculationException(Throwable) - Method in class org.cache2k.core.EntryAction
- ExpiryPolicyException - Exception in org.cache2k.core
- ExpiryPolicyException(Throwable) - Constructor for exception org.cache2k.core.ExpiryPolicyException
- expiryTicks - Variable in class org.cache2k.core.timing.StaticTiming
- explicitLoad(long) - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- explicitLoad(long) - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- explicitLoad(long) - Method in class org.cache2k.core.StandardCommonMetrics
F
- failure(RuntimeException) - Method in class org.cache2k.core.EntryAction
-
Failure call on Progress from Semantic.
- failure(RuntimeException) - Method in interface org.cache2k.core.operation.Progress
-
Bad things happened, propagate the exception to the client.
- FAILURE - Static variable in interface org.cache2k.core.api.HealthInfoElement
- findEvictionCandidate() - Method in class org.cache2k.core.eviction.AbstractEviction
-
Find a candidate for eviction.
- findEvictionCandidate() - Method in class org.cache2k.core.eviction.ClockProPlusEviction
-
Runs cold hand and in turn hot hand to find eviction candidate.
- findIdleCandidate(int) - Method in class org.cache2k.core.eviction.AbstractEviction
- findIdleCandidate(int) - Method in class org.cache2k.core.eviction.ClockProPlusEviction
-
Find idle candidate.
- findIdleInHot(int) - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- finishLoadOrEviction(Entry<K, V>, long) - Method in class org.cache2k.core.HeapCache
- formatTime(Instant) - Static method in class org.cache2k.core.util.Util
G
- generateKeySet(Iterable<? extends K>) - Static method in class org.cache2k.core.HeapCache
-
Generate a set of unique keys from the iterable.
- generateName(int) - Method in class org.cache2k.core.concurrency.GlobalThreadFactory
- get(Object) - Method in class org.cache2k.core.ConcurrentMapWrapper
- get(Object) - Method in class org.cache2k.core.MapValueConverterProxy
- get(K) - Method in class org.cache2k.core.HeapCache
- get(K) - Method in class org.cache2k.core.operation.Operations
- get(K) - Method in class org.cache2k.core.WiredCache
- GET - Static variable in class org.cache2k.core.operation.Operations
- GET_ENTRY - Static variable in class org.cache2k.core.operation.Operations
- getActions() - Method in class org.cache2k.core.BulkAction
- getActiveCaches() - Method in class org.cache2k.core.CacheManagerImpl
- getAll(Iterable<? extends K>) - Method in class org.cache2k.core.HeapCache
-
JSR107 bulk interface.
- getAll(Iterable<? extends K>) - Method in class org.cache2k.core.WiredCache
-
This takes four different execution paths depending on cache setup and state: no loader and/or all data present in heap, async or async bulk, parallel single load, bulk load.
- getAnyLoaderException() - Method in class org.cache2k.core.BulkResultCollector
-
Gets a loader exception if any value represents an exception
- getCache() - Method in interface org.cache2k.core.api.HealthInfoElement
-
Cache reporting the trouble.
- getCache() - Method in class org.cache2k.core.EntryAction
-
User facing cache interface instance.
- getCache(String) - Method in class org.cache2k.core.CacheManagerImpl
- getCacheManager() - Method in interface org.cache2k.core.api.InternalCacheBuildContext
-
The cache manager.
- getCacheManager() - Method in interface org.cache2k.core.api.InternalCacheCloseContext
-
The cache manager
- getCacheManager() - Method in class org.cache2k.core.HeapCache
- getCacheManager() - Method in class org.cache2k.core.InternalCache2kBuilder
- getCacheManager() - Method in class org.cache2k.core.WiredCache
- getCapacityLimit() - Method in class org.cache2k.core.common.BaseCacheControl
- getClassLoader() - Method in class org.cache2k.core.CacheManagerImpl
- getClearCallsCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getClearCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Number of calls to
clear
this cache has received. - getClearedCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getClearedEntriesCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Number of entries removed from the cache by the
clear
operation. - getClearedTime() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Time of last clear operation.
- getClearedTime() - Method in class org.cache2k.core.common.BaseCacheControl
- getClearOrCloseCount() - Method in class org.cache2k.core.StampedHash
- getClock() - Method in interface org.cache2k.core.api.InternalCache
-
Time reference for the cache.
- getClock() - Method in class org.cache2k.core.HeapCache
- getClock() - Method in class org.cache2k.core.WiredCache
- getCommonMetrics() - Method in interface org.cache2k.core.api.InternalCache
- getCommonMetrics() - Method in class org.cache2k.core.api.InternalConfig
- getCommonMetrics() - Method in class org.cache2k.core.HeapCache
- getCommonMetrics() - Method in class org.cache2k.core.WiredCache
- getCompressedWeight() - Method in class org.cache2k.core.Entry
- getConfig() - Method in interface org.cache2k.core.api.InternalCacheBuildContext
-
Cache configuration.
- getConfig() - Method in class org.cache2k.core.InternalCache2kBuilder
- getConfiguredCacheNames() - Method in class org.cache2k.core.CacheManagerImpl
- getConfiguredCacheNames(CacheManager) - Method in class org.cache2k.core.DummyConfigProvider
- getConfiguredCacheNames(CacheManager) - Method in interface org.cache2k.core.spi.CacheConfigProvider
-
List of cache names found in the configuration.
- getConsistentInfo() - Method in interface org.cache2k.core.api.InternalCache
-
Generate fresh statistics within a global cache lock.
- getConsistentInfo() - Method in class org.cache2k.core.HeapCache
- getConsistentInfo() - Method in class org.cache2k.core.WiredCache
- getConsistentInfo(InternalCache) - Method in class org.cache2k.core.HeapCache
- getCreatedTime() - Method in class org.cache2k.core.common.BaseCacheControl
- getCurrentEntry() - Method in class org.cache2k.core.EntryAction
-
Returns the heap entry directly.
- getCyclicListEntryCount(Entry) - Static method in class org.cache2k.core.Entry
- getDebugCount() - Method in class org.cache2k.core.log.Log.SuppressionCounter
- getDefaultClassLoader() - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- getDefaultConfig(CacheManager) - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- getDefaultConfig(CacheManager) - Method in class org.cache2k.core.DummyConfigProvider
- getDefaultConfig(CacheManager) - Method in interface org.cache2k.core.spi.CacheConfigProvider
-
A new configuration instance for mutation with default values.
- getDefaultManagerName(ClassLoader) - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- getDefaultManagerName(ClassLoader) - Method in class org.cache2k.core.DummyConfigProvider
- getDefaultManagerName(ClassLoader) - Method in interface org.cache2k.core.spi.CacheConfigProvider
-
Name for the default manager for the given class loader.
- getEntries() - Method in class org.cache2k.core.StampedHash
-
Entry table used by the iterator.
- getEntry(K) - Method in class org.cache2k.core.HeapCache
- getEntry(K) - Method in class org.cache2k.core.operation.Operations
- getEntry(K) - Method in class org.cache2k.core.WiredCache
- getEntryAction() - Method in class org.cache2k.core.Entry
- getEntryCapacity() - Method in class org.cache2k.core.common.BaseCacheControl
- getEntryCapacity() - Method in class org.cache2k.core.StampedHash
- getEntryInternal(K) - Method in class org.cache2k.core.HeapCache
- getEntryInternal(K, int, int) - Method in class org.cache2k.core.HeapCache
- getEntryState(K) - Method in interface org.cache2k.core.api.InternalCache
- getEntryState(K) - Method in class org.cache2k.core.HeapCache
- getEntryState(K) - Method in class org.cache2k.core.WiredCache
- getEvictedCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Entry was evicted.
- getEvictedCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getEvictedCount() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Number of entries evicted
- getEvictedOrRemovedWeight() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getEvictedWeight() - Method in interface org.cache2k.core.api.InternalCacheInfo
- getEvictedWeight() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Accumulated weight of evicted or deleted entries
- getEviction() - Method in interface org.cache2k.core.api.InternalCache
- getEviction() - Method in class org.cache2k.core.HeapCache
- getEviction() - Method in class org.cache2k.core.WiredCache
- getEvictionRunningCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Number of entries currently being evicted.
- getEvictionRunningCount() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Number of eviction currently going on
- getException() - Method in class org.cache2k.core.BulkAction
- getException() - Method in class org.cache2k.core.EntryAction
- getException() - Method in class org.cache2k.core.ExceptionWrapper
- getExceptionPropagator() - Method in class org.cache2k.core.ExceptionWrapper
- getExceptionPropagator() - Method in interface org.cache2k.core.operation.Progress
-
Exception propagator in effect.
- getExceptionToPropagate() - Method in class org.cache2k.core.BulkAction
- getExceptionToPropagate() - Method in class org.cache2k.core.EntryAction
-
Exception that might have happened during processing.
- getExecutor() - Method in interface org.cache2k.core.api.InternalCacheBuildContext
- getExecutor() - Method in class org.cache2k.core.BaseCache
- getExecutor() - Method in class org.cache2k.core.EntryAction
- getExecutor() - Method in class org.cache2k.core.HeapCache
- getExecutor() - Method in class org.cache2k.core.InternalCache2kBuilder
- getExecutor() - Method in class org.cache2k.core.WiredCache
- getExpiredCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Counts entries that expired.
- getExpiredCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getExpiredKeptCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getExpiredKeptCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Number of entries expired, but kept in the cache because of ongoing processing on the entry (pinned) or because keepData is enabled.
- getExpiredKeptCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getExpiredRemovedCount() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Removed entries, because expired
- getExpiryTime() - Method in class org.cache2k.core.Entry
-
Expiry time / refresh time, always positive.
- getExpiryTime() - Method in interface org.cache2k.core.operation.ExaminationEntry
- getExplicitLoadCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getExplicitLoadCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Entry was explicitly loaded, that is every load that is not read through or refresh.
- getExplicitLoadCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
- getExplicitLoadCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getFailingChecks() - Method in class org.cache2k.core.IntegrityState
- getFuture() - Method in class org.cache2k.core.OperationCompletion
- getGetCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Number of cache operations, only access
- getGetCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getGhostMax() - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- getGoneSpinCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getGoneSpinCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Entry was removed while waiting to get the mutation lock.
- getGoneSpinCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Entry was removed while waiting to get the mutation lock.
- getGoneSpinCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getHashEntries() - Method in interface org.cache2k.core.eviction.HeapCacheForEviction
-
Hash table entry array, used only by random eviction.
- getHashEntries() - Method in class org.cache2k.core.HeapCache
- getHeapCache() - Method in class org.cache2k.core.WiredCache
-
For testing
- getHeapCapacity() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Configured limit of the total cache entry capacity or -1 if weigher is used.
- getHeapHitButNoReadCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getHeapHitButNoReadCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Operation was accessing a heap entry and counted a hit if it is existing, but it should not be counted as read/get operation (e.g.
- getHeapHitButNoReadCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getHeapHitCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getHeapHitCount() - Method in interface org.cache2k.core.api.CommonMetrics
- getHeapHitCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Total counted hits on the heap cache data.
- getHeapHitCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getHitRate() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Hit rate of the cache
- getHitRate() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getHitRateString() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Hit rate of the cache in string representation
- getHotMax() - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- getId() - Method in interface org.cache2k.core.api.HealthInfoElement
-
Compact unique id of the message.
- getIdleNonEvictDrainCount() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Entries removed from the cache which have either expired or are removed programmatically, or in other words, they were removed but not evicted.
- getImplementation() - Method in interface org.cache2k.core.api.InternalCacheInfo
- getImplementation() - Method in class org.cache2k.core.common.BaseCacheControl
- getInfo() - Method in interface org.cache2k.core.api.InternalCache
-
Return cache statistic counters.
- getInfo() - Method in class org.cache2k.core.HeapCache
- getInfo() - Method in class org.cache2k.core.WiredCache
- getInfo(InternalCache) - Method in class org.cache2k.core.HeapCache
- getInfoCount() - Method in class org.cache2k.core.log.Log.SuppressionCounter
- getInfoCreatedTime() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Time when the info object was created.
- getInsertCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getInspectionEntry() - Method in class org.cache2k.core.Entry
-
Used as current entry for expiry policy, loader or resilience policy suppress.
- getIntegrityDescriptor() - Method in interface org.cache2k.core.api.InternalCacheInfo
- getIntegrityState() - Method in class org.cache2k.core.HeapCache
- getInternalExceptionCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
The cache produced an exception by itself that should have been prevented.
- getKey() - Method in class org.cache2k.core.EntryAction
- getKey() - Method in class org.cache2k.core.event.AsyncEvent
- getKey() - Method in class org.cache2k.core.ExceptionWrapper
- getKey() - Method in interface org.cache2k.core.operation.ExaminationEntry
-
Associated key
- getKeyMutationCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
After inserting into the cache the key object changed its hash code.
- getKeyMutationCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getKeyType() - Method in interface org.cache2k.core.api.InternalCache
- getKeyType() - Method in class org.cache2k.core.common.BaseCacheControl
- getKeyType() - Method in class org.cache2k.core.HeapCache
- getKeyType() - Method in class org.cache2k.core.WiredCache
- getLagTicks() - Method in class org.cache2k.core.timing.DefaultTimer
-
Lag to gather timer tasks processing.
- getLagTicks() - Method in interface org.cache2k.core.timing.Timer
-
The lag time tasks may lag behind.
- getLevel() - Method in interface org.cache2k.core.api.HealthInfoElement
- getLoadCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Successful loads including reloads and refresh.
- getLoadCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getLoadCount() - Method in interface org.cache2k.core.EventCounter
- getLoaderException() - Method in class org.cache2k.core.BulkAction
- getLoaderException() - Method in class org.cache2k.core.EntryAction
- getLoaderExecutor() - Method in class org.cache2k.core.HeapCache
- getLoadExceptionCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getLoadExceptionCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Counter of exceptions thrown from the loader.
- getLoadExceptionCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Counter of exceptions thrown from the loader.
- getLoadExceptionCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getLoadExceptionCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getLoadMillis() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Accumulated loader execution time.
- getLoadTicks() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getLoadTicks() - Method in interface org.cache2k.core.api.CommonMetrics
-
Accumulated milliseconds spend in load operations.
- getLoadTicks() - Method in class org.cache2k.core.StandardCommonMetrics
- getLoadTime() - Method in class org.cache2k.core.ExceptionWrapper
- getLockObject() - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- getLockObject() - Method in class org.cache2k.core.CacheManagerImpl
-
Used for JSR107 cache manager implementation
- getLog() - Method in interface org.cache2k.core.api.InternalCache
-
used from the cache manager
- getLog() - Method in class org.cache2k.core.HeapCache
-
Normally a cache itself logs nothing, so just construct when needed.
- getLog() - Method in class org.cache2k.core.WiredCache
- getLog(Class<?>) - Static method in class org.cache2k.core.log.Log
- getLog(String) - Static method in class org.cache2k.core.log.Log
- getLog(String) - Method in interface org.cache2k.core.log.LogFactory
- getManager(ClassLoader, String) - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- getManager(ClassLoader, String, boolean) - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- getManagerName() - Method in class org.cache2k.core.common.BaseCacheControl
- getMaximumWeight() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Configured maximum weight or -1 if entry capacity is used.
- getMaximumWeight() - Method in class org.cache2k.core.common.BaseCacheControl
- getMaxSize() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Size limit after eviction kicks in
- getMaxWeight() - Method in interface org.cache2k.core.eviction.EvictionMetrics
- getMessage() - Method in interface org.cache2k.core.api.HealthInfoElement
-
Text message describing the problem.
- getMetrics() - Method in class org.cache2k.core.eviction.AbstractEviction
- getMetrics() - Method in class org.cache2k.core.eviction.DelegatingEviction
- getMetrics() - Method in interface org.cache2k.core.eviction.Eviction
-
Get metrics related to the eviction.
- getMetrics() - Method in class org.cache2k.core.SegmentedEviction
- getMillisPerLoad() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Average duration in milliseconds for each load operation.
- getMillisPerLoad() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getMissCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
A value was requested, either the entry is not present or the data was expired.
- getMissCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getModificationTime() - Method in class org.cache2k.core.Entry
- getModificationTime() - Method in interface org.cache2k.core.operation.ExaminationEntry
- getMutationStartTime() - Method in class org.cache2k.core.EntryAction
- getMutationStartTime() - Method in interface org.cache2k.core.operation.Progress
-
The current time in millis or the value when it was first called.
- getName() - Method in interface org.cache2k.core.api.InternalCacheCloseContext
-
The cache name
- getName() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Configured name of the cache or null if anonymous.
- getName() - Method in class org.cache2k.core.CacheManagerImpl
- getName() - Method in class org.cache2k.core.common.BaseCacheControl
- getName() - Method in class org.cache2k.core.HeapCache
- getName() - Method in class org.cache2k.core.InternalCache2kBuilder
- getName() - Method in interface org.cache2k.core.timing.TimerEventListener
-
Designation of target for logging and exceptions.
- getName() - Method in class org.cache2k.core.WiredCache
- getNewEntryCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Number of created cache entries.
- getNewEntryCount() - Method in interface org.cache2k.core.eviction.EvictionMetrics
- getNextRefreshTime() - Method in class org.cache2k.core.Entry
- getOrDefault(Object, V) - Method in class org.cache2k.core.ConcurrentMapWrapper
-
Default implementation from ConcurrentMap does not account for null values.
- getPeekHitNotFreshCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getPeekHitNotFreshCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Peek, but entry available was not fresh (expired).
- getPeekHitNotFreshCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getPeekMissCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getPeekMissCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Incremented if data is requested from the cache but no entry is present (e.g.
- getPeekMissCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getPiggyBack(Class<X>) - Method in class org.cache2k.core.Entry
- getProcessingState() - Method in class org.cache2k.core.Entry
- getProperties() - Method in class org.cache2k.core.CacheManagerImpl
- getProvider() - Method in class org.cache2k.core.CacheManagerImpl
- getPutCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Entry was inserted in the cache via put or another operation not including a load.
- getPutCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getPutHitCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getPutHitCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Counted for a put that updates an existing cache entry.
- getPutHitCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getPutNewEntryCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getPutNewEntryCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Counted for a put that triggers the insert of a new cache entry.
- getPutNewEntryCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getQualifiedName() - Method in interface org.cache2k.core.api.InternalCache
- getQualifiedName() - Method in class org.cache2k.core.BaseCache
-
Returns name of the cache with manager name.
- getReadThroughCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getReadThroughCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Entry was loaded, triggered by a get().
- getReadThroughCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getRefreshCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getRefreshCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Entry was loaded again, triggered by timer
- getRefreshCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Entry was loaded again, triggered by timer.
- getRefreshCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getRefreshCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getRefreshedHitCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getRefreshedHitCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Entry on probation for refresh got hit.
- getRefreshedHitCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
A previously refreshed entry was accessed.
- getRefreshedHitCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getRefreshedHitCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getRefreshExecutor() - Method in class org.cache2k.core.HeapCache
- getRefreshFailedCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getRefreshProbationNextRefreshTime() - Method in class org.cache2k.core.Entry
- getRefreshRejectedCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getRefreshRejectedCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Refresh submit failed.
- getRefreshRejectedCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Entry was supposed to be refreshed, but there was no thread available for executing it.
- getRefreshRejectedCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getRemoveCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Removed entries, because of programmatic removal.
- getRemoveCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getRemovedCount() - Method in interface org.cache2k.core.eviction.EvictionMetrics
- getResult() - Method in class org.cache2k.core.EntryAction
- getRetryCount() - Method in class org.cache2k.core.ExceptionWrapper
- getScanCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
- getScanCount() - Method in class org.cache2k.core.eviction.AbstractEviction
- getScanCount() - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- getScanCount() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Count of entries scanned for eviction.
- getScanRound() - Method in class org.cache2k.core.Entry
- getSegmentCount() - Method in class org.cache2k.core.api.InternalConfig
- getSegmentLock(int) - Method in class org.cache2k.core.StampedHash
- getSegmentMaxFill() - Method in class org.cache2k.core.StampedHash
-
For testing
- getSinceTime() - Method in class org.cache2k.core.ExceptionWrapper
- getSize() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Current number of entries in the cache.
- getSize() - Method in class org.cache2k.core.common.BaseCacheControl
- getSize() - Method in class org.cache2k.core.eviction.AbstractEviction
- getSize() - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- getSize() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Number of entries in the eviction data structure
- getSize() - Method in class org.cache2k.core.StampedHash
-
Number of hash table entries.
- getSizeWithGlobalLock() - Method in class org.cache2k.core.StampedHash
-
Separate version of getSize expected all segments are locked.
- getStartedTime() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Time when the cache started the operation.
- getStartTime() - Method in class org.cache2k.core.EntryAction
- getState() - Method in class org.cache2k.core.timing.TimerTask
- getStateDescriptor() - Method in class org.cache2k.core.IntegrityState
- getStateFlags() - Method in class org.cache2k.core.IntegrityState
- getSuppressedExceptionCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getSuppressedExceptionCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Counter of suppressed exceptions from the loader
- getSuppressedExceptionCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Loader exception occurred, but the resilience policy decided to suppress the exception and continue to use the available value.
- getSuppressedExceptionCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getSuppressedLoadExceptionCount() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getSuppressedLoadExceptionInformation() - Method in class org.cache2k.core.Entry
- getTask() - Method in class org.cache2k.core.Entry
- getThreadFactoryProvider() - Method in class org.cache2k.core.api.InternalConfig
- getTimeReference() - Method in interface org.cache2k.core.api.InternalCacheBuildContext
-
The time reference for the cache.
- getTimeReference() - Method in class org.cache2k.core.InternalCache2kBuilder
- getTimerEventCount() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- getTimerEventCount() - Method in interface org.cache2k.core.api.CommonMetrics
-
Count of timer events delivered to this cache.
- getTimerEventCount() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Count of timer events delivered to this cache.
- getTimerEventCount() - Method in class org.cache2k.core.StandardCommonMetrics
- getTiming() - Method in class org.cache2k.core.HeapCache
-
Used for tests
- getTotalEntryCount() - Method in interface org.cache2k.core.api.InternalCache
-
This method is used for
ConcurrentMapWrapper.size()
- getTotalEntryCount() - Method in class org.cache2k.core.HeapCache
- getTotalEntryCount() - Method in class org.cache2k.core.WiredCache
- getTotalLoadMillis() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- getTotalWeight() - Method in interface org.cache2k.core.api.InternalCacheInfo
-
Current sum of entry weights as returned by the
Weigher
- getTotalWeight() - Method in class org.cache2k.core.common.BaseCacheControl
- getTotalWeight() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Accumulated weight of all entries currently controlled by eviction.
- getUntil() - Method in class org.cache2k.core.ExceptionWrapper
- getUserCache() - Method in interface org.cache2k.core.api.InternalCache
-
Cache used by user, eventually wrapped.
- getUserCache() - Method in class org.cache2k.core.WiredCache
- getValueExpiryTime() - Method in class org.cache2k.core.Entry
-
Expiry time or 0.
- getValueOrException() - Method in interface org.cache2k.core.operation.ExaminationEntry
-
Associated value or the
ExceptionWrapper
- getValueType() - Method in interface org.cache2k.core.api.InternalCache
- getValueType() - Method in class org.cache2k.core.common.BaseCacheControl
- getValueType() - Method in class org.cache2k.core.HeapCache
- getValueType() - Method in class org.cache2k.core.WiredCache
- getVersion() - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- getVersion() - Method in class org.cache2k.core.CacheManagerImpl
- getVersion() - Static method in class org.cache2k.core.util.Cache2kVersion
- getVirginRemovedCount() - Method in interface org.cache2k.core.eviction.EvictionMetrics
-
Removal of an entry that was never used
- getWarnCount() - Method in class org.cache2k.core.log.Log.SuppressionCounter
- getWriteCount() - Method in interface org.cache2k.core.EventCounter
- GlobalThreadFactory - Class in org.cache2k.core.concurrency
-
Factory which names the threads uniquely.
- GlobalThreadFactory(String) - Constructor for class org.cache2k.core.concurrency.GlobalThreadFactory
- GONE - Static variable in class org.cache2k.core.Entry
- GONE_OTHER - Static variable in class org.cache2k.core.Entry
- goneSpin() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- goneSpin() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- goneSpin() - Method in class org.cache2k.core.StandardCommonMetrics
- group(String) - Method in class org.cache2k.core.IntegrityState
H
- hasBeenIterated(K, int) - Method in class org.cache2k.core.ConcurrentEntryIterator
-
Used by the storage code to filter out already iterated keys
- hasFreshData() - Method in class org.cache2k.core.EntryAction
-
Same as
Entry.hasFreshData(TimeReference)
but keep time identically once checked to ensure timing based decisions do not change during the the processing. - hasFreshData(TimeReference) - Method in class org.cache2k.core.Entry
-
Entry has a valid value and is fresh / not expired.
- hash - Variable in class org.cache2k.core.HeapCache
- hasNext() - Method in class org.cache2k.core.ConcurrentEntryIterator
- HealthInfoElement - Interface in org.cache2k.core.api
-
Describes a single problem of a cache, for example a bad hash quality.
- heapCache - Variable in class org.cache2k.core.eviction.AbstractEviction
- HeapCache<K,V> - Class in org.cache2k.core
-
Foundation for all cache variants.
- HeapCache(InternalCacheBuildContext<K, V>) - Constructor for class org.cache2k.core.HeapCache
-
called from CacheBuilder
- HeapCacheForEviction<K,V> - Interface in org.cache2k.core.eviction
-
Interface for the eviction to the heap cache hash.
- heapHit() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- heapHit() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- heapHit() - Method in class org.cache2k.core.StandardCommonMetrics
- heapHit(Entry<K, V>) - Method in class org.cache2k.core.EntryAction
- heapHitButNoRead() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- heapHitButNoRead() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- heapHitButNoRead() - Method in class org.cache2k.core.StandardCommonMetrics
- heapMiss() - Method in class org.cache2k.core.EntryAction
I
- idleNonEvictDrainCount - Variable in class org.cache2k.core.eviction.AbstractEviction
- IdleScan - Class in org.cache2k.core.eviction
-
Scans for idle entries.
- IdleScan(TimeReference, Scheduler, Eviction, long) - Constructor for class org.cache2k.core.eviction.IdleScan
- IdleScanEviction - Class in org.cache2k.core.eviction
-
Merges in idle scanning to eviction.
- IdleScanEviction(Eviction, IdleScan) - Constructor for class org.cache2k.core.eviction.IdleScanEviction
- idleScanRound - Variable in class org.cache2k.core.eviction.AbstractEviction
-
Incremented at start of new idle scan round to account for removals.
- IMMEDIATE - Static variable in class org.cache2k.core.timing.TimeAgnosticTiming
- info() - Method in class org.cache2k.core.common.AbstractCacheStatistics
- info(String) - Method in class org.cache2k.core.log.Log
- info(String) - Method in class org.cache2k.core.log.Log.JdkLogger
- info(String) - Method in class org.cache2k.core.log.Log.Slf4jLogger
- info(String) - Method in class org.cache2k.core.log.Log.SuppressionCounter
- info(String, Throwable) - Method in class org.cache2k.core.log.Log
- info(String, Throwable) - Method in class org.cache2k.core.log.Log.JdkLogger
- info(String, Throwable) - Method in class org.cache2k.core.log.Log.Slf4jLogger
- info(String, Throwable) - Method in class org.cache2k.core.log.Log.SuppressionCounter
- init() - Method in class org.cache2k.core.HeapCache
- init() - Method in class org.cache2k.core.WiredCache
- initWithoutTimerHandler() - Method in class org.cache2k.core.HeapCache
- insert(Entry<K, V>, V, long, long, long, byte, long) - Method in class org.cache2k.core.HeapCache
- insertInList(Entry, Entry) - Static method in class org.cache2k.core.Entry
- insertIntoReplacementList(Entry) - Method in class org.cache2k.core.eviction.AbstractEviction
-
Place the entry as a new entry into the eviction data structures.
- insertIntoReplacementList(Entry) - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- insertIntoTailCyclicList(E, E) - Static method in class org.cache2k.core.Entry
- insertNewEntry(K, int, int) - Method in class org.cache2k.core.HeapCache
-
Insert new entry in all structures (hash and eviction).
- InsertOrUpdate() - Constructor for class org.cache2k.core.operation.Semantic.InsertOrUpdate
- insertOrUpdateAndCalculateExpiry(Entry<K, V>, V, long, long, long, byte) - Method in class org.cache2k.core.HeapCache
-
Calculate the next refresh time if a timer / expiry is needed and call insert.
- insertWithinLock(Entry<K, V>, int, int) - Method in class org.cache2k.core.StampedHash
-
Insert an entry.
- INSTANCE - Static variable in class org.cache2k.core.timing.DefaultSchedulerProvider
- IntegerTo16BitFloatingPoint - Class in org.cache2k.core
-
Converts an unsigned long value to a 16 bit floating point number and back.
- IntegerTo16BitFloatingPoint() - Constructor for class org.cache2k.core.IntegerTo16BitFloatingPoint
- IntegrityState - Class in org.cache2k.core
-
Used to record and check the integrity.
- IntegrityState() - Constructor for class org.cache2k.core.IntegrityState
- INTERNAL_CONFIG_DEFAULT - Static variable in interface org.cache2k.core.api.InternalCacheBuildContext
- InternalCache<K,V> - Interface in org.cache2k.core.api
-
Interface to extended cache functions for the internal components.
- InternalCache2kBuilder<K,V> - Class in org.cache2k.core
-
Method object to construct a cache2k cache.
- InternalCache2kBuilder(Cache2kConfig<K, V>, CacheManager) - Constructor for class org.cache2k.core.InternalCache2kBuilder
- InternalCache2kBuilder.WrappedAdvancedCacheLoader<K,V> - Class in org.cache2k.core
-
Starting with 2.0 we don't send an entry with an exception to the loader.
- InternalCacheBuildContext<K,V> - Interface in org.cache2k.core.api
-
Context information when a cache is build.
- InternalCacheCloseContext - Interface in org.cache2k.core.api
-
Used to know cache and manager name during close for logging and throwing exceptions.
- InternalCacheInfo - Interface in org.cache2k.core.api
-
Collection of all metrics of a cache.
- internalConfig() - Method in interface org.cache2k.core.api.InternalCacheBuildContext
-
Return internal config section or default fallback.
- InternalConfig - Class in org.cache2k.core.api
- InternalConfig() - Constructor for class org.cache2k.core.api.InternalConfig
- InternalConfig.Builder - Class in org.cache2k.core.api
- InternalEvictionListener<K,V> - Interface in org.cache2k.core.eviction
-
Internal eviction event from eviction.
- internalExceptionCnt - Variable in class org.cache2k.core.HeapCache
-
Number of internal exceptions.
- IntHeapCache<V> - Class in org.cache2k.core
-
Overwrite methods so the integer value gets stored directly in the
Entry.hashCode
field andEntry.value
is set to null. - IntHeapCache(InternalCacheBuildContext<Integer, V>) - Constructor for class org.cache2k.core.IntHeapCache
- invoke(K, EntryProcessor<K, V, R>) - Method in class org.cache2k.core.HeapCache
-
Simply the
EntryAction
based code to provide the entry processor. - invoke(K, EntryProcessor<K, V, R>) - Method in class org.cache2k.core.WiredCache
- invoke(EntryProcessor<K, V, R>) - Method in class org.cache2k.core.operation.Operations
- invokeAll(Iterable<? extends K>, EntryProcessor<K, V, R>) - Method in class org.cache2k.core.BaseCache
- invokeAll(Iterable<? extends K>, EntryProcessor<K, V, R>) - Method in class org.cache2k.core.WiredCache
- isBulkMode() - Method in class org.cache2k.core.EntryAction
- isCancelled() - Method in class org.cache2k.core.timing.TimerTask
- isClosed() - Method in class org.cache2k.core.CacheManagerImpl
- isClosed() - Method in class org.cache2k.core.HeapCache
- isClosed() - Method in class org.cache2k.core.WiredCache
- isDataAvailable() - Method in class org.cache2k.core.Entry
-
The entry value was fetched and is valid, which means it can be returned by the cache.
- isDataAvailableOrProbation() - Method in class org.cache2k.core.Entry
- isDataFresh() - Method in class org.cache2k.core.EntryAction
- isDataFresh() - Method in interface org.cache2k.core.operation.Progress
-
Entry has valid data in the cache and is not expired.
- isDataFreshOrMiss() - Method in class org.cache2k.core.EntryAction
- isDataFreshOrMiss() - Method in interface org.cache2k.core.operation.Progress
-
Entry has valid data in the cache and is not expired.
- isDataRefreshing() - Method in class org.cache2k.core.EntryAction
- isDataRefreshing() - Method in interface org.cache2k.core.operation.Progress
-
True if the entry is refreshing or refreshed and in refresh probation.
- isDebugEnabled() - Method in class org.cache2k.core.log.Log
- isDebugEnabled() - Method in class org.cache2k.core.log.Log.JdkLogger
- isDebugEnabled() - Method in class org.cache2k.core.log.Log.Slf4jLogger
- isDebugEnabled() - Method in class org.cache2k.core.log.Log.SuppressionCounter
- isDefaultManager() - Method in class org.cache2k.core.CacheManagerImpl
- isDisabled() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- isDisabled() - Method in interface org.cache2k.core.api.CommonMetrics
-
True if statistics are disabled.
- isDisabled() - Method in interface org.cache2k.core.api.InternalCache
- isDisabled() - Method in class org.cache2k.core.HeapCache
- isDisabled() - Method in class org.cache2k.core.StandardCommonMetrics
- isDisabled() - Method in class org.cache2k.core.WiredCache
- isEmpty() - Method in class org.cache2k.core.ConcurrentMapWrapper
- isEmpty() - Method in class org.cache2k.core.MapValueConverterProxy
- isExecuted() - Method in class org.cache2k.core.timing.TimerTask
- isExpiredState() - Method in class org.cache2k.core.Entry
-
The entry expired, still in the cache and subject to removal from the cache if
HeapCache.isKeepAfterExpired()
is false. - isExpiryTimeReachedOrInRefreshProbation() - Method in class org.cache2k.core.EntryAction
- isExpiryTimeReachedOrInRefreshProbation() - Method in interface org.cache2k.core.operation.Progress
-
Entry reached the expiry time and expiry event can be sent and entry state can be changed to expired.
- isGettingRefresh() - Method in class org.cache2k.core.Entry
- isGone() - Method in class org.cache2k.core.Entry
-
The entry is not present in the heap any more and was evicted, expired or removed.
- isHot() - Method in class org.cache2k.core.Entry
- isInfoEnabled() - Method in class org.cache2k.core.log.Log
- isInfoEnabled() - Method in class org.cache2k.core.log.Log.JdkLogger
- isInfoEnabled() - Method in class org.cache2k.core.log.Log.Slf4jLogger
- isInfoEnabled() - Method in class org.cache2k.core.log.Log.SuppressionCounter
- isKeepAfterExpired() - Method in class org.cache2k.core.HeapCache
- isLoaderPresent() - Method in interface org.cache2k.core.api.InternalCache
- isLoaderPresent() - Method in class org.cache2k.core.common.BaseCacheControl
- isLoaderPresent() - Method in class org.cache2k.core.EntryAction
- isLoaderPresent() - Method in class org.cache2k.core.HeapCache
- isLoaderPresent() - Method in interface org.cache2k.core.operation.Progress
-
A loader is present and the cache operates in read through.
- isLoaderPresent() - Method in class org.cache2k.core.WiredCache
- isNotYetInsertedInReplacementList() - Method in class org.cache2k.core.Entry
-
Entry was not inserted into the replacement list AND not removed from replacement list.
- isNullValuePermitted() - Method in interface org.cache2k.core.api.InternalCache
- isNullValuePermitted() - Method in class org.cache2k.core.HeapCache
- isNullValuePermitted() - Method in class org.cache2k.core.WiredCache
- isProcessing() - Method in class org.cache2k.core.Entry
- isRecordRefreshTime() - Method in class org.cache2k.core.HeapCache
- isRefreshAhead() - Method in class org.cache2k.core.EntryAction
- isRefreshAhead() - Method in class org.cache2k.core.HeapCache
- isRejectNullValues() - Method in class org.cache2k.core.HeapCache
- isRemovedFromReplacementList() - Method in class org.cache2k.core.Entry
-
Check that this entry is removed from the list, may be used in assertions.
- isResultAvailable() - Method in class org.cache2k.core.EntryAction
-
If false, the result is not set.
- isScheduled() - Method in class org.cache2k.core.timing.TimerTask
- isStatisticsEnabled() - Method in class org.cache2k.core.common.BaseCacheControl
- isSyncMode() - Method in class org.cache2k.core.BulkAction
-
Processing is synchronous e.g.
- isUnscheduled() - Method in class org.cache2k.core.timing.TimerTask
- isUpdateTimeNeeded() - Method in class org.cache2k.core.HeapCache
-
No need to update the entry last modification time.
- isValidOrExpiredAndNoException() - Method in class org.cache2k.core.Entry
-
Use this entry as currentEntry in expiry policy, loader and resilience policy
- isVirgin() - Method in class org.cache2k.core.Entry
-
Initial state of an entry.
- isWeigherPresent() - Method in interface org.cache2k.core.api.InternalCache
- isWeigherPresent() - Method in class org.cache2k.core.common.BaseCacheControl
- isWeigherPresent() - Method in class org.cache2k.core.eviction.AbstractEviction
- isWeigherPresent() - Method in class org.cache2k.core.eviction.DelegatingEviction
- isWeigherPresent() - Method in interface org.cache2k.core.eviction.Eviction
- isWeigherPresent() - Method in class org.cache2k.core.HeapCache
- isWeigherPresent() - Method in class org.cache2k.core.SegmentedEviction
- isWeigherPresent() - Method in class org.cache2k.core.WiredCache
- iterateAllHeapEntries() - Method in class org.cache2k.core.HeapCache
-
Returns all cache entries within the heap cache.
- iterator() - Method in class org.cache2k.core.BaseCache
- iterator() - Method in class org.cache2k.core.HeapCache
- iterator() - Method in class org.cache2k.core.WiredCache
J
- JdkLogger(Logger) - Constructor for class org.cache2k.core.log.Log.JdkLogger
K
- keyMutationCnt - Variable in class org.cache2k.core.HeapCache
-
Counts the number of key mutations.
- keyObjFromEntry(Entry<Integer, V>) - Method in class org.cache2k.core.IntHeapCache
- keyObjFromEntry(Entry<K, V>) - Method in class org.cache2k.core.HeapCache
-
Either returns the stored key object or the integer object created from the hashCode field.
- keyObjIsEqual(K, Entry) - Method in class org.cache2k.core.StampedHash
- keys() - Method in class org.cache2k.core.BaseCache
-
Key iteration on top of normal iterator.
- keySet() - Method in class org.cache2k.core.ConcurrentMapWrapper
- keySet() - Method in class org.cache2k.core.MapValueConverterProxy
- keyType - Variable in class org.cache2k.core.HeapCache
L
- LAST - Static variable in class org.cache2k.core.Entry.ProcessingState
- ListenerException(Throwable) - Constructor for exception org.cache2k.core.EntryAction.ListenerException
- load() - Method in class org.cache2k.core.EntryAction
- load() - Method in interface org.cache2k.core.EventCounter
- load() - Method in interface org.cache2k.core.operation.Progress
-
Request that the entry value gets loaded from loader.
- load(int) - Method in interface org.cache2k.core.EventCounter
- load(K, long, CacheEntry<K, V>) - Method in class org.cache2k.core.InternalCache2kBuilder.WrappedAdvancedCacheLoader
- load(K, AsyncCacheLoader.Context<K, V>, AsyncCacheLoader.Callback<V>) - Method in class org.cache2k.core.BulkAction
-
Load request for single value coming for entry action.
- load(Entry<K, V>) - Method in class org.cache2k.core.HeapCache
- LOAD - Static variable in class org.cache2k.core.Entry.ProcessingState
- LOAD_ASYNC - Static variable in class org.cache2k.core.Entry.ProcessingState
- LOAD_COMPLETE - Static variable in class org.cache2k.core.Entry.ProcessingState
- loadAll(Iterable<? extends K>) - Method in class org.cache2k.core.HeapCache
- loadAll(Iterable<? extends K>) - Method in class org.cache2k.core.WiredCache
- loadAndExpiryCalculatedExamineAgain() - Method in class org.cache2k.core.EntryAction
- loadAndReplace(K) - Method in class org.cache2k.core.HeapCache
-
Always fetch the value from the source.
- loadAndRestart() - Method in class org.cache2k.core.EntryAction
- loadAndRestart() - Method in interface org.cache2k.core.operation.Progress
-
Request a load, and then call examine again to reevaluate.
- loadCompleted() - Method in class org.cache2k.core.EntryAction
- loaded(K, Progress<K, V, R>, ExaminationEntry<K, V>) - Method in class org.cache2k.core.operation.Semantic.Base
-
By default a load returns always the value as result.
- loaded(K, Progress<K, V, R>, ExaminationEntry<K, V>) - Method in interface org.cache2k.core.operation.Semantic
-
Load is complete.
- loader - Variable in class org.cache2k.core.HeapCache
- loader() - Method in class org.cache2k.core.EntryAction
-
Provide the cache loader, if present.
- loadException() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- loadException() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- loadException() - Method in class org.cache2k.core.StandardCommonMetrics
- loadStart() - Method in interface org.cache2k.core.EventCounter
- lock - Variable in class org.cache2k.core.eviction.AbstractEviction
- lock - Variable in class org.cache2k.core.HeapCache
-
Structure lock of the cache.
- Log - Class in org.cache2k.core.log
-
cache2k has only sparse logging.
- Log() - Constructor for class org.cache2k.core.log.Log
- Log.JdkLogger - Class in org.cache2k.core.log
- Log.Slf4jLogger - Class in org.cache2k.core.log
- Log.SuppressionCounter - Class in org.cache2k.core.log
-
Log implementation that can be used to count suppressed log outputs.
- logAndCountInternalException(String, Throwable) - Method in interface org.cache2k.core.api.InternalCache
- logAndCountInternalException(String, Throwable) - Method in class org.cache2k.core.HeapCache
- logAndCountInternalException(String, Throwable) - Method in class org.cache2k.core.WiredCache
- LogFactory - Interface in org.cache2k.core.log
-
Service provider interface to implement to reroute cache2k logging to another log implementation.
- lookup(K, int, int) - Method in class org.cache2k.core.StampedHash
-
Lookup the entry in the hash table and return it.
- lookupEntry(K) - Method in class org.cache2k.core.HeapCache
- lookupEntry(K, int, int) - Method in class org.cache2k.core.HeapCache
- lookupEntryNoHitRecord(K) - Method in class org.cache2k.core.HeapCache
- lookupEntryNoHitRecord(K, int, int) - Method in class org.cache2k.core.HeapCache
- lookupOrNewEntry(K) - Method in class org.cache2k.core.HeapCache
-
Lookup or create a new entry.
- lookupOrNewEntry(K, int, int) - Method in class org.cache2k.core.HeapCache
- lookupOrNewEntryNoHitRecord(K) - Method in class org.cache2k.core.HeapCache
M
- manager - Variable in class org.cache2k.core.HeapCache
- managerCreated(CacheManager) - Method in interface org.cache2k.core.spi.CacheManagerLifeCycleListener
- managerDestroyed(CacheManager) - Method in interface org.cache2k.core.spi.CacheManagerLifeCycleListener
- mapOrThrowIfAllFaulty() - Method in class org.cache2k.core.BulkResultCollector
-
Return result map or throw exception if every map entry has an exception.
- MapValueConverterProxy<K,V,S> - Class in org.cache2k.core
-
Delegates all requests to the given map and converts the value.
- MapValueConverterProxy(Map<K, S>) - Constructor for class org.cache2k.core.MapValueConverterProxy
- markIterated(K, int) - Method in class org.cache2k.core.ConcurrentEntryIterator
-
Mark the key as returned by the iteration to suppress doubled iterations when we need to scan throw twice ore more, e.g.
- MAXIMAL_CHUNK_SIZE - Static variable in class org.cache2k.core.eviction.AbstractEviction
- maxSize - Variable in class org.cache2k.core.eviction.AbstractEviction
-
Size limit in number of entries.
- maxWeight - Variable in class org.cache2k.core.eviction.AbstractEviction
-
Maximum allowed weight.
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.cache2k.core.ConcurrentMapWrapper
-
Default from ConcurrentMap not working because of null values.
- metrics() - Method in class org.cache2k.core.EntryAction
-
Provide the standard metrics for updating.
- mightHaveListeners() - Method in class org.cache2k.core.EntryAction
-
True if there is any listener defined.
- MightUpdate() - Constructor for class org.cache2k.core.operation.Semantic.MightUpdate
- MINIMAL_CHUNK_SIZE - Static variable in class org.cache2k.core.eviction.AbstractEviction
- MINIMUM_CAPACITY_FOR_CHUNKING - Static variable in class org.cache2k.core.eviction.AbstractEviction
- mutate(K, Progress<K, V, Void>, ExaminationEntry<K, V>) - Method in class org.cache2k.core.operation.Operations.ExpireEvent
- mutate(K, Progress<K, V, R>, ExaminationEntry<K, V>) - Method in interface org.cache2k.core.operation.Semantic
-
Perform the mutation.
- mutate(K, Progress<K, V, R>, ExaminationEntry<K, V>) - Method in class org.cache2k.core.operation.Semantic.Read
-
No operation.
- MUTATE - Static variable in class org.cache2k.core.Entry.ProcessingState
- mutationAbort(RuntimeException) - Method in class org.cache2k.core.EntryAction
- mutationCalculateExpiry() - Method in class org.cache2k.core.EntryAction
- mutationCallWriter() - Method in class org.cache2k.core.EntryAction
- mutationDone() - Method in class org.cache2k.core.EntryAction
- mutationMayCallWriter() - Method in class org.cache2k.core.EntryAction
-
Entry mutation, call writer if needed or skip to
EntryAction.mutationMayStore()
- mutationMayStore() - Method in class org.cache2k.core.EntryAction
-
Entry mutation, call storage if needed
- mutationReleaseLockAndStartTimer() - Method in class org.cache2k.core.EntryAction
-
Mutate the entry and start timer for expiry.
N
- name - Variable in class org.cache2k.core.HeapCache
- NAME_SEPARATOR - Static variable in class org.cache2k.core.util.Util
- NeedsClose - Interface in org.cache2k.core.api
-
Internal cache component that holds resources and needs a proper close.
- NeedsLoadRestartException() - Constructor for exception org.cache2k.core.operation.Operations.NeedsLoadRestartException
- NeedsLockRestartException() - Constructor for exception org.cache2k.core.operation.Operations.NeedsLockRestartException
- needsTimeCheck() - Method in class org.cache2k.core.Entry
- needsTimeCheck(long) - Static method in class org.cache2k.core.Entry
- newCache(Cache<?, ?>, String) - Method in class org.cache2k.core.CacheManagerImpl
- newThread(Runnable) - Method in class org.cache2k.core.concurrency.GlobalThreadFactory
- newThreadFactory(String) - Method in class org.cache2k.core.concurrency.DefaultThreadFactoryProvider
- newThreadFactory(String) - Method in interface org.cache2k.core.concurrency.ThreadFactoryProvider
-
Construct a new thread factory for the pool.
- next - Variable in class org.cache2k.core.Entry
-
Lru list: pointer to next element or list head
- next() - Method in class org.cache2k.core.ConcurrentEntryIterator
- nextProcessingStep(int) - Method in class org.cache2k.core.Entry
-
Switch to another processing state that is other then done.
- nextRun() - Method in interface org.cache2k.core.timing.TimerStructure
-
Time of next run, or MAX_VALUE if no more tasks are scheduled
- nextRun() - Method in class org.cache2k.core.timing.TimerWheels
- NO_OPERATION - Static variable in interface org.cache2k.core.eviction.InternalEvictionListener
- noExpiryListenersPresent() - Method in class org.cache2k.core.EntryAction
- noMutation() - Method in class org.cache2k.core.EntryAction
- noMutation() - Method in interface org.cache2k.core.operation.Progress
-
No mutation is done.
- NON_FRESH_DUMMY - Static variable in class org.cache2k.core.EntryAction
- NOTIFY - Static variable in class org.cache2k.core.Entry.ProcessingState
- num2processingStateText(int) - Static method in class org.cache2k.core.Entry
O
- of(InternalCacheBuildContext<K, V>) - Static method in class org.cache2k.core.timing.Timing
- onEvictionFromHeap(Entry<K, V>) - Method in interface org.cache2k.core.eviction.InternalEvictionListener
- onEvictionFromHeap(Entry<K, V>) - Method in class org.cache2k.core.WiredCache
-
Calls eviction listeners.
- onLoadFailure(Iterable<? extends K>, Throwable) - Method in class org.cache2k.core.BulkAction
- onLoadFailure(Throwable) - Method in class org.cache2k.core.BulkAction
-
Fail all pending load requests.
- onLoadFailure(Throwable) - Method in class org.cache2k.core.EntryAction
-
The load failed, resilience and refreshing needs to be triggered
- onLoadFailure(K, Throwable) - Method in class org.cache2k.core.BulkAction
- onLoadSuccess(Map<? extends K, ? extends V>) - Method in class org.cache2k.core.BulkAction
- onLoadSuccess(K, V) - Method in class org.cache2k.core.BulkAction
- onLoadSuccess(V) - Method in class org.cache2k.core.EntryAction
-
Process async call back.
- onWriteFailure(Throwable) - Method in class org.cache2k.core.EntryAction
- onWriteSuccess() - Method in class org.cache2k.core.EntryAction
- OperationCompletion<K> - Class in org.cache2k.core
-
Completes when each operation for a key completes and propagates exception.
- OperationCompletion(Set<K>) - Constructor for class org.cache2k.core.OperationCompletion
- Operations<K,V> - Class in org.cache2k.core.operation
-
Semantics of all cache operations on entries.
- Operations() - Constructor for class org.cache2k.core.operation.Operations
- Operations.ExpireEvent<K,V> - Class in org.cache2k.core.operation
- Operations.NeedsLoadRestartException - Exception in org.cache2k.core.operation
- Operations.NeedsLockRestartException - Exception in org.cache2k.core.operation
- Operations.WantsDataRestartException - Exception in org.cache2k.core.operation
- org.cache2k.core - package org.cache2k.core
- org.cache2k.core.api - package org.cache2k.core.api
- org.cache2k.core.common - package org.cache2k.core.common
- org.cache2k.core.concurrency - package org.cache2k.core.concurrency
- org.cache2k.core.event - package org.cache2k.core.event
- org.cache2k.core.eviction - package org.cache2k.core.eviction
- org.cache2k.core.log - package org.cache2k.core.log
- org.cache2k.core.operation - package org.cache2k.core.operation
- org.cache2k.core.spi - package org.cache2k.core.spi
- org.cache2k.core.timing - package org.cache2k.core.timing
- org.cache2k.core.util - package org.cache2k.core.util
P
- peek(K) - Method in class org.cache2k.core.HeapCache
- peek(K) - Method in class org.cache2k.core.operation.Operations
- peek(K) - Method in class org.cache2k.core.WiredCache
- peekAll(Iterable<? extends K>) - Method in class org.cache2k.core.HeapCache
- peekAll(Iterable<? extends K>) - Method in class org.cache2k.core.WiredCache
-
We need to deal with possible null values and exceptions.
- peekAndPut(K, V) - Method in class org.cache2k.core.HeapCache
- peekAndPut(K, V) - Method in class org.cache2k.core.operation.Operations
- peekAndPut(K, V) - Method in class org.cache2k.core.WiredCache
- peekAndRemove(K) - Method in class org.cache2k.core.HeapCache
- peekAndRemove(K) - Method in class org.cache2k.core.operation.Operations
- peekAndRemove(K) - Method in class org.cache2k.core.WiredCache
- peekAndReplace(K, V) - Method in class org.cache2k.core.HeapCache
- peekAndReplace(K, V) - Method in class org.cache2k.core.operation.Operations
- peekAndReplace(K, V) - Method in class org.cache2k.core.WiredCache
- peekEntry() - Method in class org.cache2k.core.operation.Operations
- peekEntry(K) - Method in class org.cache2k.core.HeapCache
- peekEntry(K) - Method in class org.cache2k.core.WiredCache
- peekEntryInternal(K) - Method in class org.cache2k.core.HeapCache
-
Return the entry, if it is in the cache, without invoking the cache source.
- peekEntryInternal(K, int, int) - Method in class org.cache2k.core.HeapCache
- peekHitNotFresh() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- peekHitNotFresh() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- peekHitNotFresh() - Method in class org.cache2k.core.StandardCommonMetrics
- peekMiss() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- peekMiss() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- peekMiss() - Method in class org.cache2k.core.StandardCommonMetrics
- PINNED - Static variable in class org.cache2k.core.Entry.ProcessingState
- prev - Variable in class org.cache2k.core.Entry
-
Lru list: pointer to previous element or list head
- processingDone() - Method in class org.cache2k.core.Entry
- processingDone(EntryAction) - Method in class org.cache2k.core.Entry
-
Set processing state to done and notify all that wait for processing this entry.
- ProcessingState() - Constructor for class org.cache2k.core.Entry.ProcessingState
- Progress<K,V,R> - Interface in org.cache2k.core.operation
-
Interface for cache operation semantics to control the progress of the processing.
- propagate(InterruptedException) - Static method in exception org.cache2k.core.CacheOperationInterruptedException
-
Set interrupt state again and propagate exception as
CacheOperationInterruptedException
- propagateException(LoadExceptionInfo<K, V>) - Method in class org.cache2k.core.DefaultExceptionPropagator
- PROVIDER - Static variable in class org.cache2k.core.CacheManagerImpl
- put(K, Object) - Method in class org.cache2k.core.BulkResultCollector
- put(K, V) - Method in class org.cache2k.core.ConcurrentMapWrapper
- put(K, V) - Method in class org.cache2k.core.HeapCache
- put(K, V) - Method in class org.cache2k.core.MapValueConverterProxy
- put(K, V) - Method in class org.cache2k.core.operation.Operations
- put(K, V) - Method in class org.cache2k.core.WiredCache
- put(V) - Method in class org.cache2k.core.EntryAction
- put(V) - Method in interface org.cache2k.core.operation.Progress
-
Update the entry with the new value.
- putAll(Collection<EntryAction<K, V, V>>) - Method in class org.cache2k.core.BulkResultCollector
- putAll(Map<? extends K, ? extends V>) - Method in class org.cache2k.core.ConcurrentMapWrapper
- putAll(Map<? extends K, ? extends V>) - Method in class org.cache2k.core.HeapCache
- putAll(Map<? extends K, ? extends V>) - Method in class org.cache2k.core.MapValueConverterProxy
- putAll(Map<? extends K, ? extends V>) - Method in class org.cache2k.core.WiredCache
- putAndSetExpiry(V, long, long) - Method in class org.cache2k.core.EntryAction
- putAndSetExpiry(V, long, long) - Method in interface org.cache2k.core.operation.Progress
-
Set new value, skip expiry calculation and set expiry time directly.
- putHit() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- putHit() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- putHit() - Method in class org.cache2k.core.StandardCommonMetrics
- putIfAbsent(K, V) - Method in class org.cache2k.core.ConcurrentMapWrapper
-
We cannot use
Cache.putIfAbsent(Object, Object)
since the map returns the value. - putIfAbsent(K, V) - Method in class org.cache2k.core.HeapCache
- putIfAbsent(K, V) - Method in class org.cache2k.core.operation.Operations
-
Updates intentionally hit and miss counter to adjust with JSR107.
- putIfAbsent(K, V) - Method in class org.cache2k.core.WiredCache
- putNewEntry() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- putNewEntry() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- putNewEntry() - Method in class org.cache2k.core.StandardCommonMetrics
- putValue(Entry<K, V>, V) - Method in class org.cache2k.core.HeapCache
-
Update the value directly within entry lock.
Q
- queue(AsyncEvent<K>) - Method in class org.cache2k.core.event.AsyncDispatcher
-
Immediately executes an event with the provided executor.
R
- Read() - Constructor for class org.cache2k.core.operation.Semantic.Read
- READ - Static variable in class org.cache2k.core.Entry.ProcessingState
- READ_COMPLETE - Static variable in class org.cache2k.core.Entry.ProcessingState
- READ_NON_VALID - Static variable in class org.cache2k.core.Entry
- readThrough(long) - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- readThrough(long) - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- readThrough(long) - Method in class org.cache2k.core.StandardCommonMetrics
- ready() - Method in class org.cache2k.core.EntryAction
- recordHit(Entry) - Method in class org.cache2k.core.HeapCache
-
Increment the hit counter, because entry was accessed.
- reexamineAfterLock() - Method in class org.cache2k.core.EntryAction
-
Entry state may have changed between the first examination and obtaining the entry lock.
- refresh - Variable in class org.cache2k.core.operation.Operations
- refresh() - Method in class org.cache2k.core.EntryAction
- refresh() - Method in interface org.cache2k.core.operation.Progress
-
Same as load but counting statistics as refresh.
- refresh(long) - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- refresh(long) - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- refresh(long) - Method in class org.cache2k.core.StandardCommonMetrics
- REFRESH - Static variable in class org.cache2k.core.Entry.ProcessingState
- refreshAhead - Variable in class org.cache2k.core.timing.StaticTiming
- refreshedHit() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- refreshedHit() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- refreshedHit() - Method in class org.cache2k.core.StandardCommonMetrics
- refreshRejected() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- refreshRejected() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- refreshRejected() - Method in class org.cache2k.core.StandardCommonMetrics
- registerSuppression(String, Log) - Static method in class org.cache2k.core.log.Log
-
Redirects log output, this is used for testing purposes.
- reloadAll(Iterable<? extends K>) - Method in class org.cache2k.core.HeapCache
- reloadAll(Iterable<? extends K>) - Method in class org.cache2k.core.WiredCache
- remove() - Method in class org.cache2k.core.ConcurrentEntryIterator
- remove() - Method in class org.cache2k.core.EntryAction
- remove() - Method in interface org.cache2k.core.operation.Progress
-
The entry will be removed.
- remove(Object) - Method in class org.cache2k.core.ConcurrentMapWrapper
- remove(Object) - Method in class org.cache2k.core.MapValueConverterProxy
- remove(Object, Object) - Method in class org.cache2k.core.ConcurrentMapWrapper
- remove(K) - Method in class org.cache2k.core.HeapCache
- remove(K) - Method in class org.cache2k.core.operation.Operations
- remove(K) - Method in class org.cache2k.core.WiredCache
- remove(K, V) - Method in class org.cache2k.core.operation.Operations
- remove(Entry<K, V>) - Method in class org.cache2k.core.StampedHash
-
Remove existing entry from the hash.
- REMOVE_PENDING - Static variable in class org.cache2k.core.Entry
-
Cache.remove() operation received.
- removeAll() - Method in class org.cache2k.core.BaseCache
- removeAll() - Method in class org.cache2k.core.common.BaseCacheControl
- removeAll() - Method in class org.cache2k.core.eviction.AbstractEviction
- removeAll() - Method in class org.cache2k.core.eviction.DelegatingEviction
- removeAll() - Method in interface org.cache2k.core.eviction.Eviction
-
Remove all entries from the eviction data structure.
- removeAll() - Method in class org.cache2k.core.SegmentedEviction
- removeAll(Iterable<? extends K>) - Method in class org.cache2k.core.BaseCache
- removeAllFromReplacementList() - Method in class org.cache2k.core.eviction.AbstractEviction
-
Remove entries from the replacement list without locking the entry itself.
- removeAllFromReplacementList() - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- removedFromList() - Method in class org.cache2k.core.Entry
-
Reset next as a marker for
Entry.isRemovedFromReplacementList()
- removeEntry(Entry<K, V>) - Method in class org.cache2k.core.HeapCache
-
Remove the entry from the hash and the replacement list.
- removeEntryForEviction(Entry<K, V>) - Method in interface org.cache2k.core.eviction.HeapCacheForEviction
-
After removing the entry from the eviction data structure, remove it from the hash table.
- removeEntryForEviction(Entry<K, V>) - Method in class org.cache2k.core.HeapCache
-
Remove the entry from the hash table.
- removeFromCyclicList(E, E) - Static method in class org.cache2k.core.Entry
- removeFromCyclicList(Entry) - Static method in class org.cache2k.core.Entry
- removeFromList(Entry) - Static method in class org.cache2k.core.Entry
- removeFromReplacementList(Entry) - Method in class org.cache2k.core.eviction.AbstractEviction
-
Remove entry from the eviction data structures, because it was evicted or deleted.
- removeFromReplacementList(Entry) - Method in class org.cache2k.core.eviction.ClockProPlusEviction
-
Remove, expire or eviction of an entry happens.
- removeFromReplacementListOnEvict(Entry) - Method in class org.cache2k.core.eviction.AbstractEviction
-
Identical to
AbstractEviction.removeFromReplacementList(Entry)
by default but allows the eviction algorithm to do additional bookkeeping of eviction history. - removeFromReplacementListOnEvict(Entry) - Method in class org.cache2k.core.eviction.ClockProPlusEviction
-
Track the entry on the ghost list and call the usual remove procedure.
- removeIfEquals(K, V) - Method in class org.cache2k.core.HeapCache
-
Remove the object from the cache.
- removeIfEquals(K, V) - Method in class org.cache2k.core.WiredCache
- removeNextToRun(long) - Method in interface org.cache2k.core.timing.TimerStructure
-
Return a task that is supposed to execute at the given time or earlier.
- removeNextToRun(long) - Method in class org.cache2k.core.timing.TimerWheels
- removeWithinLock(Entry<K, V>, int) - Method in class org.cache2k.core.StampedHash
- replace(K, boolean, V, V) - Method in class org.cache2k.core.HeapCache
-
replace if value matches.
- replace(K, V) - Method in class org.cache2k.core.ConcurrentMapWrapper
- replace(K, V) - Method in class org.cache2k.core.HeapCache
- replace(K, V) - Method in class org.cache2k.core.operation.Operations
-
Updates intentionally hit and miss counter to adjust with JSR107.
- replace(K, V) - Method in class org.cache2k.core.WiredCache
- replace(K, V, V) - Method in class org.cache2k.core.ConcurrentMapWrapper
- replace(K, V, V) - Method in class org.cache2k.core.operation.Operations
- replaceIfEquals(K, V, V) - Method in class org.cache2k.core.HeapCache
- replaceIfEquals(K, V, V) - Method in class org.cache2k.core.WiredCache
- requestInterface(Class<X>) - Method in class org.cache2k.core.BaseCache
- resetEntryAction() - Method in class org.cache2k.core.Entry
- resetSuppressedLoadExceptionInformation() - Method in class org.cache2k.core.Entry
-
If the entry carries information about a suppressed exception, clear it.
- resiliencePolicy - Variable in class org.cache2k.core.timing.StaticTiming
- ResiliencePolicyException - Exception in org.cache2k.core
-
Exception happened in the resilience policy.
- ResiliencePolicyException(Throwable) - Constructor for exception org.cache2k.core.ResiliencePolicyException
- resolve(Class<T>) - Static method in class org.cache2k.core.SingleProviderResolver
-
Return a provider for this interface.
- resolve(Class<T>, Class<? extends T>) - Static method in class org.cache2k.core.SingleProviderResolver
-
Return a provider for this interface.
- resolveMandatory(Class<T>) - Static method in class org.cache2k.core.SingleProviderResolver
-
Return a provider for this interface.
- result(R) - Method in class org.cache2k.core.EntryAction
- result(R) - Static method in class org.cache2k.core.EntryProcessingResultFactory
- result(R) - Method in interface org.cache2k.core.operation.Progress
-
Sets the operation result.
- ResultEntry<K,V> - Interface in org.cache2k.core.operation
-
Needed for getAll and peekAll to have the valueOrException.
- resultOrWrapper(Object) - Method in class org.cache2k.core.EntryAction
- resultOrWrapper(Object) - Method in interface org.cache2k.core.operation.Progress
-
Sets the result or a wrapper
- retrieveDataFromHeap() - Method in class org.cache2k.core.EntryAction
- returnCacheEntry(K, Object) - Method in class org.cache2k.core.HeapCache
-
In case of an exception we can return the wrapper directly since it implements the CacheEntry interface and is immutable.
- returnCacheEntry(ExaminationEntry<K, V>) - Method in interface org.cache2k.core.api.InternalCache
- returnCacheEntry(ExaminationEntry<K, V>) - Method in class org.cache2k.core.HeapCache
-
Construct a new CacheEntry for the cache client.
- returnCacheEntry(ExaminationEntry<K, V>) - Method in class org.cache2k.core.WiredCache
- returnEntry(ExaminationEntry<K, V>) - Method in class org.cache2k.core.HeapCache
-
Wrap entry in a separate object instance.
- returnNullValueDetectedException() - Method in class org.cache2k.core.HeapCache
- returnValue(Object) - Static method in class org.cache2k.core.HeapCache
- returnValue(Entry<K, V>) - Method in class org.cache2k.core.HeapCache
- reviveRefreshedEntry(long) - Method in class org.cache2k.core.EntryAction
- run() - Method in class org.cache2k.core.EntryAction
- run() - Method in class org.cache2k.core.timing.TimerTask
-
For the special case of immediate execution this implements
Runnable
. - runLocked(Supplier<T>) - Method in class org.cache2k.core.eviction.AbstractEviction
- runLocked(Supplier<T>) - Method in class org.cache2k.core.eviction.DelegatingEviction
- runLocked(Supplier<T>) - Method in interface org.cache2k.core.eviction.Eviction
-
Runs job making sure concurrent evictions operations pause.
- runLocked(Supplier<T>) - Method in class org.cache2k.core.SegmentedEviction
- runMoreOrStop(AsyncEvent<K>) - Method in class org.cache2k.core.event.AsyncDispatcher
-
Run as long there is still an event for the key.
- runTotalLocked(Supplier<T>) - Method in class org.cache2k.core.StampedHash
-
Lock all segments and run the job.
S
- sampleStatistics() - Method in class org.cache2k.core.common.BaseCacheControl
- SCAN_ROUND_BITS - Static variable in class org.cache2k.core.Entry
- SCAN_ROUND_MASK - Static variable in class org.cache2k.core.Entry
-
Mask and max value for scan round
- SCAN_ROUND_POS - Static variable in class org.cache2k.core.Entry
- scanWakeup() - Method in class org.cache2k.core.eviction.IdleScan
- schedule(TimerTask, long) - Method in class org.cache2k.core.timing.DefaultTimer
-
Schedule the specified timer task for execution at the specified time, in milliseconds.
- schedule(TimerTask, long) - Method in interface org.cache2k.core.timing.Timer
-
Schedule the specified timer task for execution at the specified time, in milliseconds.
- schedule(TimerTask, long) - Method in interface org.cache2k.core.timing.TimerStructure
-
Insert task.
- schedule(TimerTask, long) - Method in class org.cache2k.core.timing.TimerWheels
- scheduleFinalTimerForSharpExpiry(Entry<K, V>) - Method in class org.cache2k.core.timing.StaticTiming
- scheduleFinalTimerForSharpExpiry(Entry<K, V>) - Method in class org.cache2k.core.timing.Timing
-
Schedule second timer event for the expiry tie if sharp expiry is switched on.
- segmentCount(int) - Method in class org.cache2k.core.api.InternalConfig.Builder
-
Segmentation count to use instead of the automatic one.
- SegmentedEviction - Class in org.cache2k.core
-
Forwards eviction operations to segments based on the hash code.
- SegmentedEviction(Eviction[]) - Constructor for class org.cache2k.core.SegmentedEviction
- Semantic<K,V,R> - Interface in org.cache2k.core.operation
-
Defines the semantic of a cache operation based on Java code that examines the cached entry and calls
Progress
for instructing the cache what needs to be done. - Semantic.Base<K,V,R> - Class in org.cache2k.core.operation
-
Base class to provide a default for the load result.
- Semantic.InsertOrUpdate<K,V,R> - Class in org.cache2k.core.operation
-
Only update the entry.
- Semantic.MightUpdate<K,V,R> - Class in org.cache2k.core.operation
-
Read a cache entry and do an optional mutation.
- Semantic.Read<K,V,R> - Class in org.cache2k.core.operation
-
Read only operation.
- Semantic.Update<K,V,R> - Class in org.cache2k.core.operation
-
Read a cache entry and do an mutation maybe based on the existing values.
- sendClosedEvent(Cache<K, V>, InternalCacheCloseContext) - Method in class org.cache2k.core.CacheManagerImpl
- sendCreatedEvent(Cache, InternalCacheBuildContext<K, V>) - Method in class org.cache2k.core.CacheManagerImpl
- setBulkMode(boolean) - Method in class org.cache2k.core.EntryAction
- setCommonMetrics(CustomizationSupplier<CommonMetrics.Updater>) - Method in class org.cache2k.core.api.InternalConfig
- setCompressedWeight(int) - Method in class org.cache2k.core.Entry
-
Store weight as 16 bit floating point number.
- setDefaultManagerName(ClassLoader, String) - Method in class org.cache2k.core.Cache2kCoreProviderImpl
- setDisabled(boolean) - Method in interface org.cache2k.core.api.InternalCache
- setDisabled(boolean) - Method in class org.cache2k.core.HeapCache
- setDisabled(boolean) - Method in class org.cache2k.core.WiredCache
- setEntryAction(EntryAction) - Method in class org.cache2k.core.Entry
- setGone() - Method in class org.cache2k.core.Entry
- setHot(boolean) - Method in class org.cache2k.core.Entry
- setNextRefreshTime(long) - Method in class org.cache2k.core.Entry
- setRefreshProbationNextRefreshTime(long) - Method in class org.cache2k.core.Entry
- setRefreshTime(long) - Method in class org.cache2k.core.Entry
-
Set modification time and marks entry as dirty.
- setScanRound(int) - Method in class org.cache2k.core.Entry
- setSegmentCount(int) - Method in class org.cache2k.core.api.InternalConfig
- setSuppressedLoadExceptionInformation(LoadExceptionInfo) - Method in class org.cache2k.core.Entry
- setTarget(TimerEventListener<K, V>) - Method in class org.cache2k.core.timing.StaticTiming
- setTarget(TimerEventListener<K, V>) - Method in class org.cache2k.core.timing.Timing
-
Set the target for timer events.
- setTask(TimerTask) - Method in class org.cache2k.core.Entry
- setThreadFactoryProvider(CustomizationSupplier<ThreadFactoryProvider>) - Method in class org.cache2k.core.api.InternalConfig
- setTiming(Timing<K, V>) - Method in class org.cache2k.core.HeapCache
- SHARP_EXPIRY_SAFETY_GAP - Static variable in class org.cache2k.core.timing.StaticTiming
-
When sharp expiry is enabled, the expiry timer goes before the actual expiry to switch back to a time checking scheme when the cache is accessed.
- sharpExpiry - Variable in class org.cache2k.core.timing.StaticTiming
- shortCircuit() - Method in class org.cache2k.core.Entry
- SingleProviderResolver - Class in org.cache2k.core
-
Loads singletons of service provider implementations.
- SingleProviderResolver() - Constructor for class org.cache2k.core.SingleProviderResolver
- SINGLETON - Static variable in class org.cache2k.core.DefaultExceptionPropagator
- SINGLETON - Static variable in class org.cache2k.core.operation.Operations
- size() - Method in class org.cache2k.core.ConcurrentMapWrapper
- size() - Method in class org.cache2k.core.MapValueConverterProxy
- skipHeapAccessEntryPresent() - Method in class org.cache2k.core.EntryAction
- skipStore() - Method in class org.cache2k.core.EntryAction
- skipWritingForException() - Method in class org.cache2k.core.EntryAction
- skipWritingNoWriter() - Method in class org.cache2k.core.EntryAction
- Slf4jLogger(Logger) - Constructor for class org.cache2k.core.log.Log.Slf4jLogger
- spreadHash(int) - Static method in class org.cache2k.core.HeapCache
-
This function calculates a modified hash code.
- spreadHashFromEntry(int) - Method in class org.cache2k.core.StampedHash
-
Return the spreaded hash code from the hash code that is stored in the entry.
- spreadHashFromEntry(Entry) - Method in class org.cache2k.core.HeapCache
- spreadHashFromEntry(Entry) - Method in class org.cache2k.core.IntHeapCache
- StampedHash<K,V> - Class in org.cache2k.core
-
Simple concurrent hash table implementation using optimistic locking via StampedLock for the segments locks.
- StampedHash(String) - Constructor for class org.cache2k.core.StampedHash
- StampedHash(InternalCache<?, ?>) - Constructor for class org.cache2k.core.StampedHash
- StandardCommonMetrics - Class in org.cache2k.core
- StandardCommonMetrics() - Constructor for class org.cache2k.core.StandardCommonMetrics
- start() - Method in class org.cache2k.core.BulkAction
- start() - Method in class org.cache2k.core.EntryAction
-
Entry point to execute this action.
- start(K, Progress<K, V, R>) - Method in class org.cache2k.core.operation.Semantic.InsertOrUpdate
-
Instruct to lock the entry for the update.
- start(K, Progress<K, V, R>) - Method in class org.cache2k.core.operation.Semantic.MightUpdate
-
Reqeust latest data
- start(K, Progress<K, V, R>) - Method in class org.cache2k.core.operation.Semantic.Read
-
Instruct to provide the cache content
- start(K, Progress<K, V, R>) - Method in interface org.cache2k.core.operation.Semantic
-
Start of the operation.
- startedTime - Variable in class org.cache2k.core.HeapCache
- startNewIdleScanRound() - Method in class org.cache2k.core.eviction.AbstractEviction
- startNewIdleScanRound() - Method in class org.cache2k.core.eviction.DelegatingEviction
- startNewIdleScanRound() - Method in interface org.cache2k.core.eviction.Eviction
-
Start new idle scan round and return current scan counter
- startNewIdleScanRound() - Method in class org.cache2k.core.SegmentedEviction
- startProcessing(int, EntryAction) - Method in class org.cache2k.core.Entry
-
Starts long operation on entry.
- startRefreshProbationTimer(Entry<K, V>, long) - Method in class org.cache2k.core.HeapCache
- startRefreshProbationTimer(Entry<K, V>, long) - Method in class org.cache2k.core.timing.StaticTiming
- startRefreshProbationTimer(Entry<K, V>, long) - Method in class org.cache2k.core.timing.Timing
-
Start probation timer.
- StaticTiming<K,V> - Class in org.cache2k.core.timing
-
Expiry time is constant
- stopStartTimer(long, Entry<K, V>) - Method in class org.cache2k.core.timing.StaticTiming
-
Calculate the needed timer value, which depends on the setting of sharpExpiry and refreshAhead.
- stopStartTimer(long, Entry<K, V>) - Method in class org.cache2k.core.timing.Timing
-
Convert expiry value to the entry field value, essentially maps 0 to
Entry.EXPIRED
since 0 is a virgin entry. - STORE - Static variable in class org.cache2k.core.Entry.ProcessingState
- STORE_COMPLETE - Static variable in class org.cache2k.core.Entry.ProcessingState
- submitWithoutTriggeringEviction(Entry) - Method in class org.cache2k.core.eviction.AbstractEviction
- submitWithoutTriggeringEviction(Entry) - Method in class org.cache2k.core.eviction.DelegatingEviction
- submitWithoutTriggeringEviction(Entry) - Method in interface org.cache2k.core.eviction.Eviction
-
Submit to eviction for inserting or removing from the replacement list.
- submitWithoutTriggeringEviction(Entry) - Method in class org.cache2k.core.SegmentedEviction
- supply(CacheBuildContext<?, ?>) - Method in class org.cache2k.core.timing.DefaultSchedulerProvider
- suppressedException() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- suppressedException() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- suppressedException() - Method in class org.cache2k.core.StandardCommonMetrics
- suppressExceptionUntil(Entry<K, V>, LoadExceptionInfo) - Method in class org.cache2k.core.timing.StaticTiming
- suppressExceptionUntil(Entry<K, V>, LoadExceptionInfo) - Method in class org.cache2k.core.timing.Timing
-
Delegated to the resilience policy
- SuppressionCounter() - Constructor for class org.cache2k.core.log.Log.SuppressionCounter
T
- ThreadFactoryProvider - Interface in org.cache2k.core.concurrency
-
Provider interface for a thread factory.
- throwIfNeeded() - Method in class org.cache2k.core.IntegrityState
- throwOnAnyLoaderException() - Method in class org.cache2k.core.BulkResultCollector
- TimeAgnosticTiming<K,V> - Class in org.cache2k.core.timing
-
Base class for all timing handlers that actually need not to know the current time.
- TimeAgnosticTiming() - Constructor for class org.cache2k.core.timing.TimeAgnosticTiming
- Timer - Interface in org.cache2k.core.timing
-
Timer for triggering expiry or refresh.
- timerEvent() - Method in class org.cache2k.core.api.CommonMetrics.BlackHole
- timerEvent() - Method in interface org.cache2k.core.api.CommonMetrics.Updater
- timerEvent() - Method in class org.cache2k.core.StandardCommonMetrics
- timerEventExpireEntry(Entry<K, V>, Object) - Method in class org.cache2k.core.HeapCache
- timerEventExpireEntry(Entry<K, V>, Object) - Method in interface org.cache2k.core.timing.TimerEventListener
-
Called by the timer when an entry is expired or before actual expiry when the entry needs to switch into sharp expiry mode.
- timerEventExpireEntry(Entry<K, V>, Object) - Method in class org.cache2k.core.WiredCache
-
If not expired yet, negate time to enforce time checks, schedule task for expiry otherwise.
- TimerEventListener<K,V> - Interface in org.cache2k.core.timing
-
Notifications from the
Timing
to theInternalCache
upon timer events. - timerEventProbationTerminated(Entry<K, V>, Object) - Method in class org.cache2k.core.HeapCache
- timerEventProbationTerminated(Entry<K, V>, Object) - Method in interface org.cache2k.core.timing.TimerEventListener
- timerEventProbationTerminated(Entry<K, V>, Object) - Method in class org.cache2k.core.WiredCache
- timerEventRefresh(Entry<K, V>, Object) - Method in class org.cache2k.core.HeapCache
- timerEventRefresh(Entry<K, V>, Object) - Method in interface org.cache2k.core.timing.TimerEventListener
-
The entry should be refreshed.
- timerEventRefresh(Entry<K, V>, Object) - Method in class org.cache2k.core.WiredCache
-
Starts a refresh operation or expires if no threads in the loader thread pool are available.
- TimerStructure - Interface in org.cache2k.core.timing
-
Interface of the timer task data structure.
- TimerTask - Class in org.cache2k.core.timing
-
Task for the simple timer
- TimerTask() - Constructor for class org.cache2k.core.timing.TimerTask
- TimerWheels - Class in org.cache2k.core.timing
-
Hierarchical timer wheel implementation.
- TimerWheels(long, long, int) - Constructor for class org.cache2k.core.timing.TimerWheels
- timing - Variable in class org.cache2k.core.HeapCache
- timing() - Method in class org.cache2k.core.EntryAction
- Timing<K,V> - Class in org.cache2k.core.timing
-
Encapsulates logic for expiry times calculation and timer handling.
- Timing() - Constructor for class org.cache2k.core.timing.Timing
- toEntryKey(Integer) - Method in class org.cache2k.core.IntHeapCache
- toEntryKey(K) - Method in class org.cache2k.core.HeapCache
-
The key object or null, for integer keyed caches
- toStoredHashCodeOrKey(Integer, int) - Method in class org.cache2k.core.IntHeapCache
- toStoredHashCodeOrKey(K, int) - Method in class org.cache2k.core.HeapCache
-
We store either the spread hash code or the raw integer key in the hash table
- toString() - Method in class org.cache2k.core.AbstractCacheEntry
-
Prints
- toString() - Method in class org.cache2k.core.BaseCache
-
Return status information.
- toString() - Method in class org.cache2k.core.CacheManagerImpl
- toString() - Method in class org.cache2k.core.Entry
- toString() - Method in class org.cache2k.core.eviction.AbstractEviction
- toString() - Method in class org.cache2k.core.eviction.ClockProPlusEviction
- toString() - Method in class org.cache2k.core.eviction.DelegatingEviction
- toString() - Method in class org.cache2k.core.eviction.IdleScan
- toString() - Method in class org.cache2k.core.eviction.IdleScanEviction
- toString() - Method in class org.cache2k.core.ExceptionWrapper
-
The exception wrapper instance is also used as
CacheEntry
directly and returned byCache.getEntry(Object)
- toString() - Method in class org.cache2k.core.SegmentedEviction
- toString() - Method in class org.cache2k.core.timing.TimerTask
- toString(HeapCache) - Method in class org.cache2k.core.Entry
U
- unconditionalLoad - Variable in class org.cache2k.core.operation.Operations
- Update() - Constructor for class org.cache2k.core.operation.Semantic.Update
- updateAccumulatedWeightInLock(Entry) - Method in class org.cache2k.core.eviction.AbstractEviction
-
Update total weight in this eviction segment.
- updateDidNotTriggerDifferentMutationStoreLoadedValue() - Method in class org.cache2k.core.EntryAction
- updateHotMax() - Method in class org.cache2k.core.eviction.AbstractEviction
-
Gets called when eviction is needed.
- updateHotMax() - Method in class org.cache2k.core.eviction.ClockProPlusEviction
-
Updates hot max based on current size.
- updateMutationStatistics() - Method in class org.cache2k.core.EntryAction
- updateTotalWeightForRemove(Entry) - Method in class org.cache2k.core.eviction.AbstractEviction
-
Called upon eviction or deletion
- updateWeight(Entry) - Method in class org.cache2k.core.eviction.AbstractEviction
- updateWeight(Entry) - Method in class org.cache2k.core.eviction.DelegatingEviction
- updateWeight(Entry) - Method in interface org.cache2k.core.eviction.Eviction
-
Updates the weight on the entry and recalculates the total weight if needed.
- updateWeight(Entry) - Method in class org.cache2k.core.SegmentedEviction
- Util - Class in org.cache2k.core.util
-
A set of utility stuff we need often.
- Util() - Constructor for class org.cache2k.core.util.Util
V
- values() - Method in class org.cache2k.core.ConcurrentMapWrapper
- values() - Method in class org.cache2k.core.MapValueConverterProxy
- valueType - Variable in class org.cache2k.core.HeapCache
- VIRGIN - Static variable in class org.cache2k.core.Entry
W
- waitForProcessing() - Method in class org.cache2k.core.Entry
- wantData() - Method in class org.cache2k.core.EntryAction
- wantData() - Method in interface org.cache2k.core.operation.Progress
-
Requests that the cache content for an entry will be provided.
- wantMutation() - Method in class org.cache2k.core.EntryAction
- wantMutation() - Method in interface org.cache2k.core.operation.Progress
-
The entry gets locked for mutation.
- WantsDataRestartException() - Constructor for exception org.cache2k.core.operation.Operations.WantsDataRestartException
- warn(String) - Method in class org.cache2k.core.log.Log.JdkLogger
- warn(String) - Method in class org.cache2k.core.log.Log.Slf4jLogger
- warn(String) - Method in class org.cache2k.core.log.Log.SuppressionCounter
- warn(String) - Method in class org.cache2k.core.log.Log
- warn(String, Throwable) - Method in class org.cache2k.core.log.Log.JdkLogger
- warn(String, Throwable) - Method in class org.cache2k.core.log.Log.Slf4jLogger
- warn(String, Throwable) - Method in class org.cache2k.core.log.Log.SuppressionCounter
- warn(String, Throwable) - Method in class org.cache2k.core.log.Log
- WARNING - Static variable in interface org.cache2k.core.api.HealthInfoElement
- wasLoaded() - Method in class org.cache2k.core.EntryAction
- wasLoaded() - Method in interface org.cache2k.core.operation.Progress
-
Value was loaded before as part of this operation.
- WiredCache<K,V> - Class in org.cache2k.core
-
A cache implementation that builds on a heap cache and coordinates with additional attachments like storage, listeners and a writer.
- WiredCache() - Constructor for class org.cache2k.core.WiredCache
- WrappedAdvancedCacheLoader(HeapCache<K, V>, AdvancedCacheLoader<K, V>) - Constructor for class org.cache2k.core.InternalCache2kBuilder.WrappedAdvancedCacheLoader
- write() - Method in interface org.cache2k.core.EventCounter
- write(int) - Method in interface org.cache2k.core.EventCounter
- WRITE - Static variable in class org.cache2k.core.Entry.ProcessingState
- WRITE_ASYNC - Static variable in class org.cache2k.core.Entry.ProcessingState
- WRITE_COMPLETE - Static variable in class org.cache2k.core.Entry.ProcessingState
- writer() - Method in class org.cache2k.core.EntryAction
-
Provide the writer, default null.
All Classes All Packages