ehcache
A B C D E F G H I J K L M N O P Q R S T U V W X

A

AATreeSet<T extends Comparable> - Class in net.sf.ehcache.store.disk.ods
A AA-Tree based SortedSet implementation
AATreeSet() - Constructor for class net.sf.ehcache.store.disk.ods.AATreeSet
 
AATreeSet.AbstractTreeNode<E> - Class in net.sf.ehcache.store.disk.ods
Abstract node implementation that can be extended with a custom payload.
AATreeSet.AbstractTreeNode() - Constructor for class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Constructs an initial (leaf) node.
AATreeSet.Node<E> - Interface in net.sf.ehcache.store.disk.ods
Interface implemented by nodes within this tree.
AbstractBalancedAccessEvictor<T> - Class in net.sf.ehcache.pool.impl
Abstract implementation of a global 'cache value' maximizing pool eviction algorithm.
AbstractBalancedAccessEvictor() - Constructor for class net.sf.ehcache.pool.impl.AbstractBalancedAccessEvictor
 
AbstractCacheWriter - Class in net.sf.ehcache.writer
A convenience abstract base class that implements all CacheWriter methods.
AbstractCacheWriter() - Constructor for class net.sf.ehcache.writer.AbstractCacheWriter
 
AbstractDepthFirstVisitor - Class in net.sf.ehcache.config.generator.model
Implementation of NodeElementVisitor that does a depth-first traversal of the element.
AbstractDepthFirstVisitor() - Constructor for class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
 
AbstractFromLargestCachePoolEvictor - Class in net.sf.ehcache.pool.impl
Abstract pool evictor which always evicts from the store consuming the most resources.
AbstractFromLargestCachePoolEvictor() - Constructor for class net.sf.ehcache.pool.impl.AbstractFromLargestCachePoolEvictor
 
AbstractNodeElement - Class in net.sf.ehcache.config.generator.model
An abstract implementation of NodeElement.
AbstractNodeElement(NodeElement) - Constructor for class net.sf.ehcache.config.generator.model.AbstractNodeElement
Constructor accepting the parent of this element
AbstractPolicy - Class in net.sf.ehcache.store
A base policy class
AbstractPolicy() - Constructor for class net.sf.ehcache.store.AbstractPolicy
 
AbstractPool<T> - Class in net.sf.ehcache.pool.impl
An abstract pool implementation.
AbstractPool(long, PoolEvictor<T>, SizeOfEngine) - Constructor for class net.sf.ehcache.pool.impl.AbstractPool
Create an AbstractPool instance
AbstractPoolAccessor<T> - Class in net.sf.ehcache.pool.impl
Abstract PoolAccessor implementation providing pool to store binding functionality.
AbstractPoolAccessor(Pool<T>, T, SizeOfEngine) - Constructor for class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Creates an accessor for the specified store to access the specified pool.
AbstractStore - Class in net.sf.ehcache.store
 
AbstractStore() - Constructor for class net.sf.ehcache.store.AbstractStore
 
AbstractStoreCommand - Class in net.sf.ehcache.transaction.xa.commands
 
AbstractStoreCommand(Element, Element) - Constructor for class net.sf.ehcache.transaction.xa.commands.AbstractStoreCommand
Create a Store Command
AbstractTransactionStore - Class in net.sf.ehcache.transaction
Abstract transactional store which provides implementation of all non-transactional methods
AbstractTransactionStore(Store, ReadWriteCopyStrategy<Element>) - Constructor for class net.sf.ehcache.transaction.AbstractTransactionStore
Constructor
accept(NodeElementVisitor) - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Accepts an NodeElementVisitor
accept(NodeElementVisitor) - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Accepts an NodeElementVisitor
accept(Object) - Method in interface net.sf.ehcache.search.aggregator.AggregatorInstance
Add the given value to the aggregator function
accept(Object) - Method in class net.sf.ehcache.search.aggregator.Average
Add the given value to the aggregator function
accept(Object) - Method in class net.sf.ehcache.search.aggregator.Count
Add the given value to the aggregator function
accept(Object) - Method in class net.sf.ehcache.search.aggregator.Max
Add the given value to the aggregator function
accept(Object) - Method in class net.sf.ehcache.search.aggregator.Min
Add the given value to the aggregator function
accept(Object) - Method in class net.sf.ehcache.search.aggregator.Sum
Add the given value to the aggregator function
accessStrategyFactory - Variable in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
The EhcacheAccessStrategyFactory used for creating various access strategies
acquireCachePeers(Ehcache) - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Acquires the cache peers for this cache.
acquireReadLockOnKey(Object) - Method in class net.sf.ehcache.Cache
Acquires the proper read lock for a given cache key
acquireReadLockOnKey(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Acquires the proper read lock for a given cache key
acquireReadLockOnKey(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Acquires the proper read lock for a given cache key
acquireReadLockOnKey(Object) - Method in interface net.sf.ehcache.Ehcache
Acquires the proper read lock for a given cache key
acquireWriteLockOnKey(Object) - Method in class net.sf.ehcache.Cache
Acquires the proper write lock for a given cache key
acquireWriteLockOnKey(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Acquires the proper write lock for a given cache key
acquireWriteLockOnKey(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Acquires the proper write lock for a given cache key
acquireWriteLockOnKey(Object) - Method in interface net.sf.ehcache.Ehcache
Acquires the proper write lock for a given cache key
add(CollectionStats) - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
 
add(EntityStats) - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
 
add(QueryStats) - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
 
add(Object, Object, Object, boolean) - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Add an element to the pool.
add(long, boolean) - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Add a specific number of bytes to the pool.
add(Object, Object, Object, boolean) - Method in interface net.sf.ehcache.pool.PoolAccessor
Add an element to the pool.
add(Object) - Method in class net.sf.ehcache.store.CacheKeySet
You can't add to this set, will throw!
add(T) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
 
add(E) - Method in class net.sf.ehcache.util.LargeCollection
add(E) - Method in class net.sf.ehcache.util.SetAsList
add(int, E) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
addAll(Collection) - Method in class net.sf.ehcache.store.CacheKeySet
You can't add to this set, will throw!
addAll(Collection<? extends E>) - Method in class net.sf.ehcache.util.SetAsList
addAll(int, Collection<? extends E>) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
addAllFactoryConfigsAsChildElements(NodeElement, String, Collection<? extends FactoryConfiguration>) - Static method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Helper method that adds all the FactoryConfiguration from the parameter as child elements by creating FactoryConfigurationElement for each of them
addAttribute(NodeAttribute) - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Add an attribute
addAttribute(NodeAttribute) - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Add an attribute
addBootstrapCacheLoaderFactory(CacheConfiguration.BootstrapCacheLoaderFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Allows BeanHandler to add the CacheManagerEventListener to the configuration.
addCache(String) - Method in class net.sf.ehcache.CacheManager
Adds a Ehcache based on the defaultCache with the given name.
addCache(Cache) - Method in class net.sf.ehcache.CacheManager
Adds a Cache to the CacheManager.
addCache(Ehcache) - Method in class net.sf.ehcache.CacheManager
Adds an Ehcache to the CacheManager.
addCache(CacheConfiguration) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to add Cache Configurations to the configuration.
addCacheDecoratorFactory(CacheConfiguration.CacheDecoratorFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Used by BeanUtils to add each cacheDecoratorFactory to the cache configuration.
addCacheEventListenerFactory(CacheConfiguration.CacheEventListenerFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Used by BeanUtils to add cacheEventListenerFactory elements to the cache configuration.
addCacheExceptionHandlerFactory(CacheConfiguration.CacheExceptionHandlerFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Add the CacheExceptionHandlerFactory to the configuration.
addCacheExtensionFactory(CacheConfiguration.CacheExtensionFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Used by BeanUtils to add cacheExtensionFactory elements to the cache configuration.
addCacheIfAbsent(Ehcache) - Method in class net.sf.ehcache.CacheManager
Only adds the cache to the CacheManager should not one with the same name already be present
addCacheIfAbsent(String) - Method in class net.sf.ehcache.CacheManager
Only creates and adds the cache to the CacheManager should not one with the same name already be present
addCacheLoaderFactory(CacheConfiguration.CacheLoaderFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Used by BeanUtils to add each cacheLoaderFactory to the cache configuration.
addCacheManagerEventListenerFactory(FactoryConfiguration) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to add the CacheManagerEventListener to the configuration.
addCacheManagerPeerListenerFactory(FactoryConfiguration) - Method in class net.sf.ehcache.config.Configuration
Adds a CacheManagerPeerListener through FactoryConfiguration.
addCacheManagerPeerProviderFactory(FactoryConfiguration) - Method in class net.sf.ehcache.config.Configuration
Adds a CacheManagerPeerProvider through FactoryConfiguration.
addCacheWriter(CacheWriterConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Allows BeanHandler to add the CacheWriterConfiguration to the configuration.
addCacheWriterFactory(CacheWriterConfiguration.CacheWriterFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Allows BeanHandler to add the CacheWriterFactory to the configuration.
addChildElement(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Adds a child element.
addChildElement(NodeElement) - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Adds a child element.
addCommand(Command, Element) - Method in class net.sf.ehcache.transaction.xa.XATransactionContext
Add a command to the current LocalTransactionContext
addCommonAttributesWithDefaultCache(NodeElement, Configuration, CacheConfiguration) - Static method in class net.sf.ehcache.config.generator.model.elements.CacheConfigurationElement
Adds all attributes which are common with the "defaultCache" element in ehcache.xsd
addCommonChildElementsWithDefaultCache(NodeElement, CacheConfiguration) - Static method in class net.sf.ehcache.config.generator.model.elements.CacheConfigurationElement
Adds all common child elements with the "defaultCache" element in ehcache.xsd
addConfigurationListener(CacheConfigurationListener) - Method in class net.sf.ehcache.config.CacheConfiguration
Add a listener to this cache configuration
addCopyStrategy(CopyStrategyConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the CopyStrategyConfiguration for this cache
addCriteria(Criteria) - Method in interface net.sf.ehcache.search.Query
Adds a criteria to the query
addDecoratedCache(Ehcache) - Method in class net.sf.ehcache.CacheManager
Adds a decorated Ehcache to the CacheManager.
addDecoratedCacheIfAbsent(Ehcache) - Method in class net.sf.ehcache.CacheManager
Same as CacheManager.addDecoratedCache(Ehcache) but does not throw exception if another cache with same name already exists.
addDefaultCache(CacheConfiguration) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to add a default configuration to the configuration.
addDiskStore(DiskStoreConfiguration) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to add disk store location to the configuration.
addElementValueComparator(ElementValueComparatorConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the ElementValueComparatorConfiguration for this cache
addGetTimeMillis(long) - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Adds time taken for a get operation in the cache
addGetTimeMillis(long) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Adds time taken for a get operation in the cache
addGetTimeMillis(long) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Adds time taken for a get operation in the cache
addGetTimeMillis(long) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Adds time taken for a get operation in the cache
addListener(TransactionListener) - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Add a TransactionListener to this context
addNonstop(NonstopConfiguration) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Add the NonstopConfiguration
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
 
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
 
addOrderBy(Attribute<?>, Direction) - Method in interface net.sf.ehcache.search.Query
Request result set ordering by the given attribute and direction.
addPinning(PinningConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Allows BeanHandler to add the PinningConfiguration to the configuration.
addPropertyChangeListener(PropertyChangeListener) - Method in class net.sf.ehcache.Cache
 
addPropertyChangeListener(PropertyChangeListener) - Method in class net.sf.ehcache.config.Configuration
Adds a PropertyChangeListener for this configuration
addPropertyChangeListener(PropertyChangeListener) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Add a PropertyChangeListener.
addPropertyChangeListener(PropertyChangeListener) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Add a PropertyChangeListener.
addPropertyChangeListener(PropertyChangeListener) - Method in interface net.sf.ehcache.Ehcache
Add a PropertyChangeListener.
addSearchable(Searchable) - Method in class net.sf.ehcache.config.CacheConfiguration
Add configuration to make this cache searchable
addSearchAttribute(SearchAttribute) - Method in class net.sf.ehcache.config.Searchable
Add the given search attribute
addSizeOfPolicy(SizeOfPolicyConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the SizeOfPolicyConfiguration for this cache.
addSizeOfPolicy(SizeOfPolicyConfiguration) - Method in class net.sf.ehcache.config.Configuration
Sets the default SizeOfPolicyConfiguration for this cache manager.
addStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Add a listener to the store.
addStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Add a listener to the store.
addStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Add a listener to the store.
addStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Add a listener to the store.
addStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Add a listener to the store.
addStoreListener(StoreListener) - Method in class net.sf.ehcache.store.AbstractStore
Add a listener to the store.
addStoreListener(StoreListener) - Method in interface net.sf.ehcache.store.Store
Add a listener to the store.
addTerracotta(TerracottaConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Allows BeanHandler to add the TerracottaConfiguration to the configuration.
addTerracottaConfig(TerracottaClientConfiguration) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to add a Terracotta configuration to the configuration
addTimeoutBehavior(TimeoutBehaviorConfiguration) - Method in class net.sf.ehcache.config.NonstopConfiguration
Set the value of timeoutBehavior
addToMeasuredSize(long) - Method in exception net.sf.ehcache.pool.sizeof.MaxDepthExceededException
Add to the partially measured size
addTopologyListener(ClusterTopologyListener) - Method in interface net.sf.ehcache.cluster.CacheCluster
Add a listener for cluster events
addTopologyListener(ClusterTopologyListener) - Method in class net.sf.ehcache.cluster.NoopCacheCluster
Add a listener for cluster events
addTopologyListener(ClusterTopologyListener) - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Add a listener for cluster events
addToReplicationQueue(RmiEventMessage) - Method in class net.sf.ehcache.distribution.RMIAsynchronousCacheReplicator
Adds a message to the queue.
addTransactionManagerLookup(FactoryConfiguration) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to add transaction manager lookup to the configuration.
addTwoPcExecutionListener(XAExecutionListener) - Method in interface net.sf.ehcache.transaction.xa.EhcacheXAResource
Add a listener which will be called back according to the 2PC lifecycle
addTwoPcExecutionListener(XAExecutionListener) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
Add a listener which will be called back according to the 2PC lifecycle
afterCommit() - Method in interface net.sf.ehcache.transaction.local.TransactionListener
This method gets called right after the transaction is committed
afterCommitOrRollback(EhcacheXAResource) - Method in interface net.sf.ehcache.transaction.xa.XAExecutionListener
Called when the resource committed or rolled back
afterInsert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. A No-Op.
afterInsert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. Inserts the specified item into the cache.
afterInsert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. 
afterInsert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
afterInsert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
Returns false since this is a non-strict read/write cache access strategy
afterInsert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
afterInsert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.ReadWriteEhcacheEntityRegionAccessStrategy
afterInsert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
afterRollback() - Method in interface net.sf.ehcache.transaction.local.TransactionListener
This method gets called right after the transaction is rolled back
afterUpdate(Object, Object, Object, SoftLock) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. Removes the invalidated item.
afterUpdate(Object, Object, Object, SoftLock) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. Throws UnsupportedOperationException since items in a read-only cache should not be mutated.
afterUpdate(Object, Object, Object, SoftLock) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. 
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
Throws UnsupportedOperationException since this cache is read-only
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.ReadWriteEhcacheEntityRegionAccessStrategy
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
AgentSizeOf - Class in net.sf.ehcache.pool.sizeof
SizeOf implementation that relies on a Java agent to be loaded to do the measurement It will try to load the agent through the JDK6 Attach API if available All it's constructor do throw UnsupportedOperationException if the agent isn't present or couldn't be loaded dynamically
AgentSizeOf() - Constructor for class net.sf.ehcache.pool.sizeof.AgentSizeOf
Builds a new SizeOf that will not filter fields and will cache reflected fields
AgentSizeOf(SizeOfFilter) - Constructor for class net.sf.ehcache.pool.sizeof.AgentSizeOf
Builds a new SizeOf that will filter fields according to the provided filter and will cache reflected fields
AgentSizeOf(SizeOfFilter, boolean) - Constructor for class net.sf.ehcache.pool.sizeof.AgentSizeOf
Builds a new SizeOf that will filter fields according to the provided filter
aggregate(CacheRegionStats) - Method in class net.sf.ehcache.hibernate.management.impl.AggregateCacheRegionStats
 
AggregateCacheRegionStats - Class in net.sf.ehcache.hibernate.management.impl
 
AggregateCacheRegionStats(String) - Constructor for class net.sf.ehcache.hibernate.management.impl.AggregateCacheRegionStats
 
AggregateIterator<T> - Class in net.sf.ehcache.util
This Iterator iterates over a collection of iterators.
AggregateIterator(Collection<?>, List<Iterator<T>>) - Constructor for class net.sf.ehcache.util.AggregateIterator
 
AggregateOnlyResult - Class in net.sf.ehcache.search.impl
A result implementation intended solely for holding aggregate results.
AggregateOnlyResult(StoreQuery) - Constructor for class net.sf.ehcache.search.impl.AggregateOnlyResult
Constructor
aggregateResult() - Method in interface net.sf.ehcache.search.aggregator.AggregatorInstance
Retrieve the final result
aggregateResult() - Method in class net.sf.ehcache.search.aggregator.Average
Retrieve the final result
aggregateResult() - Method in class net.sf.ehcache.search.aggregator.Count
Retrieve the final result
aggregateResult() - Method in class net.sf.ehcache.search.aggregator.Max
Retrieve the final result
aggregateResult() - Method in class net.sf.ehcache.search.aggregator.Min
Retrieve the final result
aggregateResult() - Method in class net.sf.ehcache.search.aggregator.Sum
Retrieve the final result
Aggregator - Interface in net.sf.ehcache.search.aggregator
An Aggregator describes a requested aggregation for a query and provides aggregator instances for execution
AggregatorException - Exception in net.sf.ehcache.search.aggregator
Thrown if an Aggregator cannot complete.
AggregatorException(String) - Constructor for exception net.sf.ehcache.search.aggregator.AggregatorException
AggregatorException
AggregatorInstance<T> - Interface in net.sf.ehcache.search.aggregator
An AggregatorInstance takes input objects and computes an aggregate function from them.
Aggregators - Class in net.sf.ehcache.search.aggregator
Helper class to construct the builtin aggregator types.
alive() - Method in interface net.sf.ehcache.distribution.CacheReplicator
Checks that the replicator is is STATUS_ALIVE.
alive() - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Checks that the replicator is is STATUS_ALIVE.
all() - Method in class net.sf.ehcache.search.impl.ResultsImpl
Retrieve all of the cache results in one shot.
all() - Method in class net.sf.ehcache.search.NullResults
Retrieve all of the cache results in one shot.
all() - Method in interface net.sf.ehcache.search.Results
Retrieve all of the cache results in one shot.
ALL_CACHE_MANAGERS - Static variable in class net.sf.ehcache.CacheManager
Keeps track of all known CacheManagers.
alloc(long) - Method in class net.sf.ehcache.store.disk.ods.FileAllocationTree
Allocate a new region of the given size.
allows(Object) - Method in interface net.sf.ehcache.store.disk.ElementSubstituteFilter
Returns true if this object passes the filter.
allowsDynamicCacheConfig() - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
 
AlwaysMatch - Class in net.sf.ehcache.search.expression
Criteria that always return true
AlwaysMatch() - Constructor for class net.sf.ehcache.search.expression.AlwaysMatch
 
and(Criteria) - Method in class net.sf.ehcache.search.expression.AlwaysMatch
Produce a criteria that is the boolean "and" of this and the given other criteria
And - Class in net.sf.ehcache.search.expression
A search criteria composed of the logical "and" of two or more other criteria
And(Criteria, Criteria) - Constructor for class net.sf.ehcache.search.expression.And
Simple constructor for two criteria
and(Criteria) - Method in class net.sf.ehcache.search.expression.And
 
and(Criteria) - Method in class net.sf.ehcache.search.expression.BaseCriteria
Produce a criteria that is the boolean "and" of this and the given other criteria
and(Criteria) - Method in interface net.sf.ehcache.search.expression.Criteria
Produce a criteria that is the boolean "and" of this and the given other criteria
AnnotationSizeOfFilter - Class in net.sf.ehcache.pool.sizeof.filter
A Filter that will filter fields, based on the IgnoreSizeOf annotation
AnnotationSizeOfFilter() - Constructor for class net.sf.ehcache.pool.sizeof.filter.AnnotationSizeOfFilter
 
areAnyExplicitLocksAcquired() - Method in class net.sf.ehcache.constructs.nonstop.concurrency.ExplicitLockingContextThreadLocal
Returns true if the thread has acquired any locks previously and not released yet
asConfigElement(NodeElement) - Method in class net.sf.ehcache.config.SearchAttribute
Create a generated config element node for this search attribute definition
assertRequiredCoreVersionPresent() - Method in class net.sf.ehcache.util.ProductInfo
Assert that the current product is compatible with the version of ehcache available on the classpath
assignFreePort(boolean) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Assigns a free port to be the listener port.
asynchronous - Variable in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Whether to load asynchronously
AtomicRateStatistic - Class in net.sf.ehcache.util.ratestatistics
A thread-safe rate statistic implementation.
AtomicRateStatistic(long, TimeUnit) - Constructor for class net.sf.ehcache.util.ratestatistics.AtomicRateStatistic
Create an AtomicRateStatistic instance with the given average period.
attemptResolutionOfUniqueResourceConflict() - Method in interface net.sf.ehcache.distribution.CacheManagerPeerListener
If a conflict is detected in unique resource use, this method signals the listener to attempt automatic resolution of the resource conflict.
attemptResolutionOfUniqueResourceConflict() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
If a conflict is detected in unique resource use, this method signals the listener to attempt automatic resolution of the resource conflict.
Attribute<T> - Class in net.sf.ehcache.search
A search attribute.
Attribute(String) - Constructor for class net.sf.ehcache.search.Attribute
Construct a new attribute instance.
AttributeExtractor - Interface in net.sf.ehcache.search.attribute
Used to extract a search attribute value for a given cache element.

Instances must be Serializable in order to ensure identical extractors are used in distributed caches
AttributeExtractorException - Exception in net.sf.ehcache.search.attribute
An exception to indicate that an attribute extractor was unable to be processed.
AttributeExtractorException(String) - Constructor for exception net.sf.ehcache.search.attribute.AttributeExtractorException
Construct a AttributeExtractorException
AttributeExtractorException(String, Throwable) - Constructor for exception net.sf.ehcache.search.attribute.AttributeExtractorException
Construct a AttributeExtractorException with an underlying cause and message
AttributeExtractorException(Throwable) - Constructor for exception net.sf.ehcache.search.attribute.AttributeExtractorException
Construct a AttributeExtractorException with an underlying cause
attributeFor(Element, String) - Method in interface net.sf.ehcache.search.attribute.AttributeExtractor
Extract the attribute value.
attributeFor(Element, String) - Method in class net.sf.ehcache.search.attribute.JavaBeanAttributeExtractor
Extract the attribute value.
attributeFor(Element, String) - Method in class net.sf.ehcache.search.attribute.KeyObjectAttributeExtractor
Extract the attribute value.
attributeFor(Element, String) - Method in class net.sf.ehcache.search.attribute.ReflectionAttributeExtractor
Evaluate the expression for the given element
attributeFor(Element, String) - Method in class net.sf.ehcache.search.attribute.ValueObjectAttributeExtractor
Extract the attribute value.
attributeFor(Element, String) - Method in class net.sf.ehcache.transaction.TransactionAwareAttributeExtractor
Extract the attribute value.
attributes - Variable in class net.sf.ehcache.config.generator.model.AbstractNodeElement
List of attributes
AttributeType - Enum in net.sf.ehcache.search.attribute
Defines the legal set of runtime types for search attributes
authority - Variable in class net.sf.ehcache.store.FrontEndCacheTier
The authority tier store
AUTO_DISK_PATH_DIRECTORY_PREFIX - Static variable in class net.sf.ehcache.store.disk.DiskStorageFactory
Path stub used to create unique ehcache directories.
AUTO_DISK_PATH_DIRECTORY_PREFIX - Static variable in class net.sf.ehcache.store.disk.DiskStore
If the CacheManager needs to resolve a conflict with the disk path, it will create a subdirectory in the given disk path with this prefix followed by a number.
average(Attribute<?>) - Static method in class net.sf.ehcache.search.aggregator.Aggregators
Construct an average value aggregator
Average - Class in net.sf.ehcache.search.aggregator
Compute the average (arithmetic mean) as a double
Average(Attribute<?>) - Constructor for class net.sf.ehcache.search.aggregator.Average
 
average() - Method in class net.sf.ehcache.search.Attribute
Request an average value aggregation of this attribute

B

BalancedAccessOnDiskPoolEvictor - Class in net.sf.ehcache.pool.impl
Balanced access evictor that makes on-disk eviction decisions.
BalancedAccessOnDiskPoolEvictor() - Constructor for class net.sf.ehcache.pool.impl.BalancedAccessOnDiskPoolEvictor
 
BalancedAccessOnHeapPoolEvictor - Class in net.sf.ehcache.pool.impl
Balanced access evictor that makes on-heap eviction decisions.
BalancedAccessOnHeapPoolEvictor() - Constructor for class net.sf.ehcache.pool.impl.BalancedAccessOnHeapPoolEvictor
 
BaseCriteria - Class in net.sf.ehcache.search.expression
Base class for all criteria types
BaseCriteria() - Constructor for class net.sf.ehcache.search.expression.BaseCriteria
 
BaseEmitterBean - Class in net.sf.ehcache.hibernate.management.impl
 
BaseEmitterBean(Class<T>) - Constructor for class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
BaseEmitterBean
BaseResult - Class in net.sf.ehcache.search.impl
Base result implementation
BaseResult(StoreQuery) - Constructor for class net.sf.ehcache.search.impl.BaseResult
Constructor
basicGetAttribute(String) - Method in class net.sf.ehcache.search.impl.AggregateOnlyResult
 
basicGetAttribute(String) - Method in class net.sf.ehcache.search.impl.BaseResult
Get the actual attribute value
basicGetAttribute(String) - Method in class net.sf.ehcache.search.impl.ResultImpl
 
basicGetKey() - Method in class net.sf.ehcache.search.impl.AggregateOnlyResult
 
basicGetKey() - Method in class net.sf.ehcache.search.impl.BaseResult
Get the actual key value
basicGetKey() - Method in class net.sf.ehcache.search.impl.ResultImpl
 
basicGetValue() - Method in class net.sf.ehcache.search.impl.AggregateOnlyResult
 
basicGetValue() - Method in class net.sf.ehcache.search.impl.BaseResult
Get the actual value
basicGetValue() - Method in class net.sf.ehcache.search.impl.ResultImpl
 
BatchOperation - Interface in net.sf.ehcache.writer.writebehind.operations
Interface to implement batch operations that are executed on a cache writer
BeanUtils - Class in net.sf.ehcache.hibernate.management.impl
Reflective utilities for dealing with backward-incompatible change to statistics types in Hibernate 3.5.
BeanUtils() - Constructor for class net.sf.ehcache.hibernate.management.impl.BeanUtils
 
beforeCommit() - Method in interface net.sf.ehcache.transaction.local.TransactionListener
This method gets called right before the transaction is committed
beforePrepare(EhcacheXAResource) - Method in interface net.sf.ehcache.transaction.xa.XAExecutionListener
Called when the resource is about to prepare
begin() - Method in class net.sf.ehcache.TransactionController
Begin a new transaction and bind its context to the current thread
begin(int) - Method in class net.sf.ehcache.TransactionController
Begin a new transaction with the specified timeout and bind its context to the current thread
beginTransactionIfNeeded(Ehcache) - Static method in class net.sf.ehcache.util.CacheTransactionHelper
Begin a transaction on the current thread if the cache is configured as transactional, otherwise this method does nothing.
between(T, T) - Method in class net.sf.ehcache.search.Attribute
Create a range criteria between the given min/max (inclusive).
between(T, T, boolean, boolean) - Method in class net.sf.ehcache.search.Attribute
Create a range criteria between the given min/max with specified inclusiveness
Between - Class in net.sf.ehcache.search.expression
Range criteria
Between(String, Object, Object, boolean, boolean) - Constructor for class net.sf.ehcache.search.expression.Between
Constructor
BIN_DIGITS - Static variable in class net.sf.ehcache.util.Timestamper
Value for left shifting System.currentTimeMillis, freeing some space for the counter
bind(String, RMICachePeer) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Bind a cache peer
bind(DiskStore) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Bind a store instance to this factory.
BlockingCache - Class in net.sf.ehcache.constructs.blocking
A blocking decorator for an Ehcache, backed by a Ehcache.
BlockingCache(Ehcache, int) - Constructor for class net.sf.ehcache.constructs.blocking.BlockingCache
Creates a BlockingCache which decorates the supplied cache.
BlockingCache(Ehcache) - Constructor for class net.sf.ehcache.constructs.blocking.BlockingCache
Creates a BlockingCache which decorates the supplied cache.
bootstrap() - Method in class net.sf.ehcache.Cache
Bootstrap command.
bootstrap() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Bootstrap command.
bootstrap() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Bootstrap command.
bootstrap() - Method in interface net.sf.ehcache.Ehcache
Bootstrap command.
BOOTSTRAP_ASYNCHRONOUSLY - Static variable in class net.sf.ehcache.bootstrap.BootstrapCacheLoaderFactory
The property name expected in ehcache.xml for the bootstrap asyncrhonously switch.
BootstrapCacheLoader - Interface in net.sf.ehcache.bootstrap
 
BootstrapCacheLoaderFactory<T extends BootstrapCacheLoader> - Class in net.sf.ehcache.bootstrap
An abstract factory for creating BootstrapCacheLoader instances.
BootstrapCacheLoaderFactory() - Constructor for class net.sf.ehcache.bootstrap.BootstrapCacheLoaderFactory
 
bootstrapCacheLoaderFactory(CacheConfiguration.BootstrapCacheLoaderFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
 
bootstrapCacheLoaderFactoryConfiguration - Variable in class net.sf.ehcache.config.CacheConfiguration
The BootstrapCacheLoaderFactoryConfiguration.
BoundedPool - Class in net.sf.ehcache.pool.impl
A pool which loosely obeys to its bound: it can allow the accessors to consume more bytes than what has been configured if that helps concurrency.
BoundedPool(long, PoolEvictor<PoolableStore>, SizeOfEngine) - Constructor for class net.sf.ehcache.pool.impl.BoundedPool
Create a BoundedPool instance
bufferFull() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Return true if the disk write queue is full.
bufferFull() - Method in class net.sf.ehcache.store.disk.DiskStore
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.store.LruMemoryStore
Memory stores are never backed up and always return false
bufferFull() - Method in class net.sf.ehcache.store.MemoryStore
Memory stores are never backed up and always return false
bufferFull() - Method in class net.sf.ehcache.store.NullStore
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in interface net.sf.ehcache.store.Store
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
bufferFull() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Some store types, such as the disk stores can fill their write buffers if puts come in too fast.
buildAccessStrategy(AccessType) - Method in class net.sf.ehcache.hibernate.regions.EhcacheCollectionRegion
buildAccessStrategy(AccessType) - Method in class net.sf.ehcache.hibernate.regions.EhcacheEntityRegion
BULK_OPS_TIMEOUT_MULTIPLY_FACTOR - Static variable in class net.sf.ehcache.config.NonstopConfiguration
System Property name for bulk operations multiply factor
BYPASS_LOADING - Static variable in class net.sf.ehcache.pool.sizeof.AgentSizeOf
System property name to bypass attaching to the VM and loading of Java agent to measure Object sizes.
byteSize(T) - Method in class net.sf.ehcache.pool.impl.AbstractBalancedAccessEvictor
Return the size in bytes of the supplied store.
byteSize(PoolableStore) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnDiskPoolEvictor
Return the size in bytes of the supplied store.
byteSize(PoolableStore) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnHeapPoolEvictor
Return the size in bytes of the supplied store.

C

Cache - Class in net.sf.ehcache
Cache is the central class in ehcache.
Cache(CacheConfiguration) - Constructor for class net.sf.ehcache.Cache
2.0 and higher Constructor

The ConfigurationFactory and clients can create these.

Cache(CacheConfiguration, RegisteredEventListeners, BootstrapCacheLoader) - Constructor for class net.sf.ehcache.Cache
2.0 and higher Constructor

The ConfigurationFactory and clients can create these.

Cache(String, int, boolean, boolean, long, long) - Constructor for class net.sf.ehcache.Cache
1.0 Constructor.
Cache(String, int, boolean, boolean, long, long, boolean, long) - Constructor for class net.sf.ehcache.Cache
1.1 Constructor.
Cache(String, int, MemoryStoreEvictionPolicy, boolean, String, boolean, long, long, boolean, long, RegisteredEventListeners) - Constructor for class net.sf.ehcache.Cache
1.2 Constructor

The ConfigurationFactory and clients can create these.

Cache(String, int, MemoryStoreEvictionPolicy, boolean, String, boolean, long, long, boolean, long, RegisteredEventListeners, BootstrapCacheLoader) - Constructor for class net.sf.ehcache.Cache
1.2.1 Constructor

The ConfigurationFactory and clients can create these.

Cache(String, int, MemoryStoreEvictionPolicy, boolean, String, boolean, long, long, boolean, long, RegisteredEventListeners, BootstrapCacheLoader, int) - Constructor for class net.sf.ehcache.Cache
1.2.4 Constructor

The ConfigurationFactory and clients can create these.

Cache(String, int, MemoryStoreEvictionPolicy, boolean, String, boolean, long, long, boolean, long, RegisteredEventListeners, BootstrapCacheLoader, int, int) - Constructor for class net.sf.ehcache.Cache
1.3 Constructor

The ConfigurationFactory and clients can create these.

Cache(String, int, MemoryStoreEvictionPolicy, boolean, String, boolean, long, long, boolean, long, RegisteredEventListeners, BootstrapCacheLoader, int, int, boolean) - Constructor for class net.sf.ehcache.Cache
1.6.0 Constructor

The ConfigurationFactory and clients can create these.

Cache(String, int, MemoryStoreEvictionPolicy, boolean, String, boolean, long, long, boolean, long, RegisteredEventListeners, BootstrapCacheLoader, int, int, boolean, boolean, String, boolean) - Constructor for class net.sf.ehcache.Cache
1.7.0 Constructor

The ConfigurationFactory and clients can create these.

cache(CacheConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder to add a new cache through its config
cache - Variable in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Used by InternalClassLoaderAwareCache
cache - Variable in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
Ehcache instance backing this Hibernate data region.
Cache - Class in net.sf.ehcache.management
A JMX MBean implementation for Cache
Cache(Ehcache) - Constructor for class net.sf.ehcache.management.Cache
A constructor for JCache.
cache - Variable in class net.sf.ehcache.store.FrontEndCacheTier
The cache tier store
cache - Variable in class net.sf.ehcache.store.LruMemoryStore
The cache this store is associated with.
CACHE_CHANGED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheMBean
CACHE_CHANGED
CACHE_CLEARED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheMBean
CACHE_CLEARED
CACHE_ENABLED - Static variable in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
CACHE_ENABLED
CACHE_ENABLED - Static variable in interface net.sf.ehcache.hibernate.management.api.HibernateStats
CACHE_ENABLED
CACHE_ENABLED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheMBean
CACHE_ENABLED
CACHE_FLUSHED - Static variable in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
CACHE_FLUSHED
CACHE_FLUSHED - Static variable in interface net.sf.ehcache.hibernate.management.api.HibernateStats
CACHE_FLUSHED
CACHE_FLUSHED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheMBean
CACHE_FLUSHED
CACHE_MANAGER_CHANGED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
CACHE_MANAGER_CHANGED
CACHE_REGION_CHANGED - Static variable in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
CACHE_REGION_CHANGED
CACHE_REGION_CHANGED - Static variable in interface net.sf.ehcache.hibernate.management.api.HibernateStats
CACHE_REGION_CHANGED
CACHE_REGION_FLUSHED - Static variable in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
CACHE_REGION_FLUSHED
CACHE_REGION_FLUSHED - Static variable in interface net.sf.ehcache.hibernate.management.api.HibernateStats
CACHE_REGION_FLUSHED
CACHE_STATISTICS_ENABLED - Static variable in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
CACHE_STATISTICS_ENABLED
CACHE_STATISTICS_ENABLED - Static variable in interface net.sf.ehcache.hibernate.management.api.HibernateStats
CACHE_STATISTICS_ENABLED
CACHE_STATISTICS_ENABLED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheMBean
CACHE_STATISTICS_ENABLED
CACHE_STATISTICS_RESET - Static variable in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
CACHE_STATISTICS_RESET
CACHE_STATISTICS_RESET - Static variable in interface net.sf.ehcache.hibernate.management.api.HibernateStats
CACHE_STATISTICS_RESET
CACHE_STATISTICS_RESET - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheMBean
CACHE_STATISTICS_RESET
CacheCluster - Interface in net.sf.ehcache.cluster
Allows you to explore the Terracotta cluster nodes and register for events about the cluster.
CacheConfigError - Class in net.sf.ehcache.config
Represents a config error in a cache configuration
CacheConfigError(String, String) - Constructor for class net.sf.ehcache.config.CacheConfigError
Constructor
CacheConfiguration - Class in net.sf.ehcache.config
A value object used to represent cache configuration.
CacheConfiguration() - Constructor for class net.sf.ehcache.config.CacheConfiguration
Default constructor.
CacheConfiguration(String, int) - Constructor for class net.sf.ehcache.config.CacheConfiguration
Create a new cache configuration.
CacheConfiguration - Class in net.sf.ehcache.management
A JMX MBean implementation and decorator to net.sf.ehcache.CacheConfiguration
CacheConfiguration(Ehcache) - Constructor for class net.sf.ehcache.management.CacheConfiguration
Constructs using a backing CacheConfiguration
CacheConfiguration.BootstrapCacheLoaderFactoryConfiguration - Class in net.sf.ehcache.config
Configuration for the BootstrapCacheLoaderFactoryConfiguration.
CacheConfiguration.BootstrapCacheLoaderFactoryConfiguration() - Constructor for class net.sf.ehcache.config.CacheConfiguration.BootstrapCacheLoaderFactoryConfiguration
 
CacheConfiguration.CacheDecoratorFactoryConfiguration - Class in net.sf.ehcache.config
Configuration for the CacheDecoratorFactoryConfiguration.
CacheConfiguration.CacheDecoratorFactoryConfiguration() - Constructor for class net.sf.ehcache.config.CacheConfiguration.CacheDecoratorFactoryConfiguration
 
CacheConfiguration.CacheEventListenerFactoryConfiguration - Class in net.sf.ehcache.config
Configuration for the CacheEventListenerFactory.
CacheConfiguration.CacheEventListenerFactoryConfiguration() - Constructor for class net.sf.ehcache.config.CacheConfiguration.CacheEventListenerFactoryConfiguration
 
CacheConfiguration.CacheExceptionHandlerFactoryConfiguration - Class in net.sf.ehcache.config
Configuration for the BootstrapCacheLoaderFactoryConfiguration.
CacheConfiguration.CacheExceptionHandlerFactoryConfiguration() - Constructor for class net.sf.ehcache.config.CacheConfiguration.CacheExceptionHandlerFactoryConfiguration
 
CacheConfiguration.CacheExtensionFactoryConfiguration - Class in net.sf.ehcache.config
Configuration for the CacheExtensionFactoryConfiguration.
CacheConfiguration.CacheExtensionFactoryConfiguration() - Constructor for class net.sf.ehcache.config.CacheConfiguration.CacheExtensionFactoryConfiguration
 
CacheConfiguration.CacheLoaderFactoryConfiguration - Class in net.sf.ehcache.config
Configuration for the CacheLoaderFactoryConfiguration.
CacheConfiguration.CacheLoaderFactoryConfiguration() - Constructor for class net.sf.ehcache.config.CacheConfiguration.CacheLoaderFactoryConfiguration
 
CacheConfiguration.TransactionalMode - Enum in net.sf.ehcache.config
Represents whether the Cache is transactional or not.
CacheConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
Element representing the CacheConfiguration
CacheConfigurationElement(NodeElement, Configuration, CacheConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.CacheConfigurationElement
Constructor accepting the parent and the CacheConfiguration
CacheConfigurationListener - Interface in net.sf.ehcache.config
Instances of CacheConfigurationListener can be registered with CacheConfiguration instances in order to receive notification when any of the dynamic properties of the configuration are changed.
CacheConfigurationMBean - Interface in net.sf.ehcache.management
A JMX MBean interface for the configuration of a cache
cacheDecoratorConfigurations - Variable in class net.sf.ehcache.config.CacheConfiguration
The cache decorator factories added by BeanUtils.
CacheDecoratorFactory - Class in net.sf.ehcache.constructs
An abstract factory for creating decorated Ehcache instances.
CacheDecoratorFactory() - Constructor for class net.sf.ehcache.constructs.CacheDecoratorFactory
 
CacheEntry - Class in net.sf.ehcache
Helper class to tie a key to an element.
CacheEntry(Object, Element) - Constructor for class net.sf.ehcache.CacheEntry
Creates a new cache entry.
CacheEntryFactory - Interface in net.sf.ehcache.constructs.blocking
Creates objects to populate the cache.
CacheEventListener - Interface in net.sf.ehcache.event
Allows implementers to register callback methods that will be executed when a cache event occurs.
CacheEventListenerAdapter - Class in net.sf.ehcache.event
An adapter to simplify cache event listeners that do not need all events defined on the CacheEventListener interface.
CacheEventListenerAdapter() - Constructor for class net.sf.ehcache.event.CacheEventListenerAdapter
 
cacheEventListenerConfigurations - Variable in class net.sf.ehcache.config.CacheConfiguration
The event listener factories added by BeanUtils.
cacheEventListenerFactory(CacheConfiguration.CacheEventListenerFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
 
CacheEventListenerFactory - Class in net.sf.ehcache.event
An abstract factory for creating listeners.
CacheEventListenerFactory() - Constructor for class net.sf.ehcache.event.CacheEventListenerFactory
 
CacheException - Exception in net.sf.ehcache
A runtime Cache Exception.
CacheException() - Constructor for exception net.sf.ehcache.CacheException
Constructor for the CacheException object.
CacheException(String) - Constructor for exception net.sf.ehcache.CacheException
Constructor for the CacheException object.
CacheException(String, Throwable) - Constructor for exception net.sf.ehcache.CacheException
Constructs a new CacheException with the specified detail message and cause.
CacheException(Throwable) - Constructor for exception net.sf.ehcache.CacheException
Constructs a new CacheException with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
CacheExceptionHandler - Interface in net.sf.ehcache.exceptionhandler
A handler which may be registered with an Ehcache, to handle exceptions on Cache operations.
cacheExceptionHandlerFactory(CacheConfiguration.CacheExceptionHandlerFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
 
CacheExceptionHandlerFactory - Class in net.sf.ehcache.exceptionhandler
An abstract factory for creating CacheExceptionHandlers at configuration time, in ehcache.xml.
CacheExceptionHandlerFactory() - Constructor for class net.sf.ehcache.exceptionhandler.CacheExceptionHandlerFactory
 
cacheExceptionHandlerFactoryConfiguration - Variable in class net.sf.ehcache.config.CacheConfiguration
The CacheExceptionHandlerFactoryConfiguration.
cacheExists(String) - Method in class net.sf.ehcache.CacheManager
Checks whether a cache of type ehcache exists.
CacheExtension - Interface in net.sf.ehcache.extension
This is a general purpose mechanism to allow generic extensions to a Cache.
cacheExtensionConfigurations - Variable in class net.sf.ehcache.config.CacheConfiguration
The cache extension factories added by BeanUtils.
cacheExtensionFactory(CacheConfiguration.CacheExtensionFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
 
CacheExtensionFactory - Class in net.sf.ehcache.extension
An abstract factory for creating CacheExtensions.
CacheExtensionFactory() - Constructor for class net.sf.ehcache.extension.CacheExtensionFactory
 
cacheHitCount - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
cacheHitCount
cacheHitInMemory() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called on a cache hit in the MemoryStore
cacheHitInMemory() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called on a cache hit in the MemoryStore
cacheHitInMemory() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called on a cache hit in the MemoryStore
cacheHitInMemory() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called on a cache hit in the MemoryStore
cacheHitOffHeap() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called on a cache hit in the off-heap
cacheHitOffHeap() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called on a cache hit in the off-heap
cacheHitOffHeap() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called on a cache hit in the off-heap
cacheHitOffHeap() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called on a cache hit in the off-heap
cacheHitOnDisk() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called on a cache hit in the DiskStore
cacheHitOnDisk() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called on a cache hit in the DiskStore
cacheHitOnDisk() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called on a cache hit in the DiskStore
cacheHitOnDisk() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called on a cache hit in the DiskStore
CacheInitializationHelper - Class in net.sf.ehcache
Helper class to initialize an Ehcache with a CacheManager without adding the Ehcache to the CacheManager.
CacheInitializationHelper(CacheManager) - Constructor for class net.sf.ehcache.CacheInitializationHelper
Create a cache initializer with the given CacheManager
CacheKeySet<E> - Class in net.sf.ehcache.store
A Set of keys that will encapsulate keys present in a Cache.
CacheKeySet(Collection<E>...) - Constructor for class net.sf.ehcache.store.CacheKeySet
Create a new Set for all tiers in the cache.
CacheLoader - Interface in net.sf.ehcache.loader
Extends JCache CacheLoader with load methods that take an argument in addition to a key This interface has exactly the same interface as in the JCache module.
cacheLoaderConfigurations - Variable in class net.sf.ehcache.config.CacheConfiguration
The cache loader factories added by BeanUtils.
cacheLoaderFactory(CacheConfiguration.CacheLoaderFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
 
CacheLoaderFactory - Class in net.sf.ehcache.loader
An abstract factory for creating cache loaders.
CacheLoaderFactory() - Constructor for class net.sf.ehcache.loader.CacheLoaderFactory
 
cacheLoaderTimeoutMillis - Variable in class net.sf.ehcache.config.CacheConfiguration
Timeout in milliseconds for CacheLoader related calls
CacheLockProvider - Interface in net.sf.ehcache.concurrent
 
CacheManager - Class in net.sf.ehcache
A container for Ehcaches that maintain all aspects of their lifecycle.
CacheManager(Configuration) - Constructor for class net.sf.ehcache.CacheManager
An constructor for CacheManager, which takes a configuration object, rather than one created by parsing an ehcache.xml file.
CacheManager(String) - Constructor for class net.sf.ehcache.CacheManager
An ordinary constructor for CacheManager.
CacheManager(URL) - Constructor for class net.sf.ehcache.CacheManager
An ordinary constructor for CacheManager.
CacheManager(InputStream) - Constructor for class net.sf.ehcache.CacheManager
An ordinary constructor for CacheManager.
CacheManager() - Constructor for class net.sf.ehcache.CacheManager
Constructor.
cacheManager - Variable in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
The CacheManager this peer provider is associated with.
CacheManager - Class in net.sf.ehcache.management
An MBean implementation for those attributes and operations we wish to expose on net.sf.ehcache.CacheManager.
CacheManager(CacheManager) - Constructor for class net.sf.ehcache.management.CacheManager
Create a management CacheManager
CacheManagerEventListener - Interface in net.sf.ehcache.event
Allows implementers to register callback methods that will be executed when a CacheManager event occurs.
cacheManagerEventListenerFactory(FactoryConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder to set the event lister through a factory, only one of these can be added and subsequent calls are ignored.
CacheManagerEventListenerFactory - Class in net.sf.ehcache.event
An abstract factory for creating CacheManagerEventListeners.
CacheManagerEventListenerFactory() - Constructor for class net.sf.ehcache.event.CacheManagerEventListenerFactory
 
cacheManagerEventListenerRegistry - Variable in class net.sf.ehcache.CacheManager
The listener registry
CacheManagerEventListenerRegistry - Class in net.sf.ehcache.event
Registered listeners for registering and unregistering CacheManagerEventListeners and sending notifications to registrants.
CacheManagerEventListenerRegistry() - Constructor for class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Construct a new registry
CacheManagerExecutorServiceFactory - Class in net.sf.ehcache.constructs.nonstop
NonstopExecutorServiceFactory that creates and maintains one per CacheManager
CacheManagerMBean - Interface in net.sf.ehcache.management
An MBean interface for those attributes and operations we wish to expose on net.sf.ehcache.CacheManager
CacheManagerPeerListener - Interface in net.sf.ehcache.distribution
A listener for updates, which controls remote cache peers.
cacheManagerPeerListenerFactory(FactoryConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder method to add a peer listener through a factory.
CacheManagerPeerListenerFactory - Class in net.sf.ehcache.distribution
An abstract factory for creating cache manager peer listeners.
CacheManagerPeerListenerFactory() - Constructor for class net.sf.ehcache.distribution.CacheManagerPeerListenerFactory
 
cacheManagerPeerListeners - Variable in class net.sf.ehcache.CacheManager
The map of listeners
CacheManagerPeerProvider - Interface in net.sf.ehcache.distribution
Provides a discovery service to locate CachePeer listener peers for a Cache.
cacheManagerPeerProviderFactory(FactoryConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder method to add a peer provider through a factory.
CacheManagerPeerProviderFactory - Class in net.sf.ehcache.distribution
An abstract factory for creating peers.
CacheManagerPeerProviderFactory() - Constructor for class net.sf.ehcache.distribution.CacheManagerPeerProviderFactory
 
cacheManagerPeerProviders - Variable in class net.sf.ehcache.CacheManager
The map of providers
CacheMBean - Interface in net.sf.ehcache.management
A management bean for a cache
cacheMissCount - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
cacheMissCount
cacheMissExpired() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called when an element is found in the cache but already expired
cacheMissExpired() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called when an element is found in the cache but already expired
cacheMissExpired() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called when an element is found in the cache but already expired
cacheMissExpired() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called when an element is found in the cache but already expired
cacheMissInMemory() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called on a cache miss in the MemoryStore
cacheMissInMemory() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called on a cache miss in the MemoryStore
cacheMissInMemory() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called on a cache miss in the MemoryStore
cacheMissInMemory() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called on a cache miss in the MemoryStore
cacheMissNotFound() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called when an element is not found in the cache
cacheMissNotFound() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called when an element is not found in the cache
cacheMissNotFound() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called when an element is not found in the cache
cacheMissNotFound() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called when an element is not found in the cache
cacheMissOffHeap() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called on a cache miss in the off-heap
cacheMissOffHeap() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called on a cache miss in the off-heap
cacheMissOffHeap() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called on a cache miss in the off-heap
cacheMissOffHeap() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called on a cache miss in the off-heap
cacheMissOnDisk() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called on a cache miss in the DiskStore
cacheMissOnDisk() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called on a cache miss in the DiskStore
cacheMissOnDisk() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called on a cache miss in the DiskStore
cacheMissOnDisk() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called on a cache miss in the DiskStore
CacheOperationUnderExplicitLockCallable<V> - Class in net.sf.ehcache.constructs.nonstop.concurrency
Callable used with nonstop when explicit lock has been acquired
CacheOperationUnderExplicitLockCallable(ExplicitLockingContext, NonstopConfiguration, Callable<V>) - Constructor for class net.sf.ehcache.constructs.nonstop.concurrency.CacheOperationUnderExplicitLockCallable
public constructor
CachePeer - Interface in net.sf.ehcache.distribution
An interface for a cache peer to which updates are made remotely.
cachePeers - Variable in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
The cache peers.
cachePutCount - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
cachePutCount
CacheRegionStats - Class in net.sf.ehcache.hibernate.management.impl
 
CacheRegionStats(String) - Constructor for class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
CacheRegionStats(String, SecondLevelCacheStatistics) - Constructor for class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
CacheRegionStats(CompositeData) - Constructor for class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
CacheRegionUtils - Class in net.sf.ehcache.hibernate.management.impl
CacheRegionUtils
CacheRegionUtils() - Constructor for class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
 
CacheReplicator - Interface in net.sf.ehcache.distribution
Replicates cache entries to peers of the CacheManager
CACHES_CLEARED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
CACHES_CLEARED
CACHES_ENABLED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
CACHES_ENABLED
CacheStatistics - Class in net.sf.ehcache.management
A JMX CacheStatistics decorator for an ehcache Statistics class.
CacheStatistics(Ehcache, long, TimeUnit) - Constructor for class net.sf.ehcache.management.CacheStatistics
Constructs an object from an ehcache statistics object
CacheStatistics(Ehcache) - Constructor for class net.sf.ehcache.management.CacheStatistics
Constructs an object from an ehcache statistics object using the default statistics ttl.
CacheStatisticsMBean - Interface in net.sf.ehcache.management
 
CacheStoreHelper - Class in net.sf.ehcache
A helper class to get the internal Store from a Cache
CacheStoreHelper(Cache) - Constructor for class net.sf.ehcache.CacheStoreHelper
Constructor accepting the cache
CacheTransactionHelper - Class in net.sf.ehcache.util
A collection of utility methods helping controlling transactions for managed operations which may require them.
CacheTransactionHelper() - Constructor for class net.sf.ehcache.util.CacheTransactionHelper
 
CacheUsageListener - Interface in net.sf.ehcache.statistics
Interface for listeners to any change in usage statistics of an Ehcache.
cacheWriter(CacheWriterConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
 
CacheWriter - Interface in net.sf.ehcache.writer
A CacheWriter is an interface used for write-through and write-behind caching to a underlying resource.
cacheWriterConfiguration - Variable in class net.sf.ehcache.config.CacheConfiguration
The CacheWriterConfiguration.
CacheWriterConfiguration - Class in net.sf.ehcache.config
Class to hold the CacheWriterManager configuration
CacheWriterConfiguration() - Constructor for class net.sf.ehcache.config.CacheWriterConfiguration
 
CacheWriterConfiguration.CacheWriterFactoryConfiguration - Class in net.sf.ehcache.config
Configuration for the CacheWriterFactoryConfiguration.
CacheWriterConfiguration.CacheWriterFactoryConfiguration() - Constructor for class net.sf.ehcache.config.CacheWriterConfiguration.CacheWriterFactoryConfiguration
 
CacheWriterConfiguration.WriteMode - Enum in net.sf.ehcache.config
Represents how elements are written to the CacheWriter
CacheWriterConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
Element representing the CacheWriterConfiguration
CacheWriterConfigurationElement(NodeElement, CacheWriterConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.CacheWriterConfigurationElement
Constructor accepting the parent and the CacheWriterConfiguration
cacheWriterFactory(CacheWriterConfiguration.CacheWriterFactoryConfiguration) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
CacheWriterFactory - Class in net.sf.ehcache.writer
An abstract factory for creating cache writers.
CacheWriterFactory() - Constructor for class net.sf.ehcache.writer.CacheWriterFactory
 
CacheWriterManager - Interface in net.sf.ehcache.writer
A CacheWriterManager coordinates how element are written to a back-end store.
CacheWriterManagerException - Exception in net.sf.ehcache.writer
An exception specifically for throwing exceptions that happen with a CacheWriterManager implementation.
CacheWriterManagerException(RuntimeException) - Constructor for exception net.sf.ehcache.writer.CacheWriterManagerException
Construct a new exception
cacheXA(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
calculateHostAddress() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Calculates the host address as the default NICs IP address
calculateInMemorySize() - Method in class net.sf.ehcache.Cache
Gets the size of the memory store for this cache.
calculateInMemorySize() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets the size of the memory store for this cache

Warning: This method can be very expensive to run.

calculateInMemorySize() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets the size of the memory store for this cache

Warning: This method can be very expensive to run.

calculateInMemorySize() - Method in interface net.sf.ehcache.Ehcache
Gets the size of the memory store for this cache

Warning: This method can be very expensive to run.

calculateOffHeapSize() - Method in class net.sf.ehcache.Cache
Gets the size of the off-heap store for this cache.
calculateOffHeapSize() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets the size of the off-heap store for this cache
calculateOffHeapSize() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets the size of the off-heap store for this cache
calculateOffHeapSize() - Method in interface net.sf.ehcache.Ehcache
Gets the size of the off-heap store for this cache
calculateOnDiskSize() - Method in class net.sf.ehcache.Cache
Gets the size of the on-disk store for this cache
calculateOnDiskSize() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets the size of the on-disk store for this cache
calculateOnDiskSize() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets the size of the on-disk store for this cache
calculateOnDiskSize() - Method in interface net.sf.ehcache.Ehcache
Gets the size of the on-disk store for this cache
calculateSampleSize(int) - Static method in class net.sf.ehcache.store.AbstractPolicy
sampleSize how many samples to take
call() - Method in class net.sf.ehcache.constructs.nonstop.concurrency.CacheOperationUnderExplicitLockCallable
call() - Method in class net.sf.ehcache.constructs.nonstop.store.RejoinAwareBlockingOperation
.
canAddWithoutEvicting(Object, Object, Object) - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Check if there is enough room in the pool to add an element without provoking any eviction
canAddWithoutEvicting(long) - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Check if there is enough room in the pool to add a specific number of bytes without provoking any eviction
canAddWithoutEvicting(Object, Object, Object) - Method in interface net.sf.ehcache.pool.PoolAccessor
Check if there is enough room in the pool to add an element without provoking any eviction
cancel() - Method in class net.sf.ehcache.util.FailSafeTimer
If the runtime environment restricts thread creation, this method does nothing.
canLockEntries() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated.  
canParticipateInSerialization() - Method in class net.sf.ehcache.DefaultElementEvictionData
Indicates whether the data of this element eviction instance can participate in serialization of the element as a whole.
canParticipateInSerialization() - Method in interface net.sf.ehcache.ElementEvictionData
Indicates whether the data of this element eviction instance can participate in serialization of the element as a whole.
canPutWithoutEvicting(Element) - Method in class net.sf.ehcache.store.MemoryStore
Check if adding an element won't provoke an eviction.
CastingOperationConverter - Class in net.sf.ehcache.writer.writebehind
A converter that simply casts an existing KeyBasedOperation instance.
changeDiskCapacity(int) - Method in class net.sf.ehcache.store.disk.DiskStore
Change the disk capacity, in number of elements
check(Class, Class) - Static method in class net.sf.ehcache.constructs.nonstop.util.OverrideCheck
Method to check a subclass overrides all methods in its superclass or the interface it implements
checkForUpdate() - Method in class net.sf.ehcache.util.UpdateChecker
This method ensures that there will be no exception thrown.
checkLinked() - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Throws IllegalStateException if this accessor is not linked to it's pool.
checkStatus() - Method in class net.sf.ehcache.CacheManager
Checks the state of the CacheManager for legal operation
children - Variable in class net.sf.ehcache.config.generator.model.AbstractNodeElement
List of child elements
CircularLossyQueue<T> - Class in net.sf.ehcache.util
An implementation of a CircularQueue data-structure.
CircularLossyQueue(int) - Constructor for class net.sf.ehcache.util.CircularLossyQueue
Constructs the circular queue with the specified capacity
classLoader - Variable in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Used by InternalClassLoaderAwareCache
ClassLoaderAwareCache - Class in net.sf.ehcache.constructs.classloader
A cache decorator that adjusts the Thread context classloader (TCCL) for every cache operation.
ClassLoaderAwareCache(Ehcache, ClassLoader) - Constructor for class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Constructor
ClassLoaderUtil - Class in net.sf.ehcache.util
Keeps all classloading in ehcache consistent.
className(String) - Method in class net.sf.ehcache.config.FactoryConfiguration
 
className(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the attribute extractor class name
cleanUp() - Method in class net.sf.ehcache.util.WeakIdentityConcurrentMap
 
cleanUp(T) - Method in interface net.sf.ehcache.util.WeakIdentityConcurrentMap.CleanUpTask
 
cleanUpFailedMarker(Serializable) - Method in class net.sf.ehcache.store.disk.DiskStore
Will check whether a Placeholder that failed to flush to disk is lying around If so, it'll try to evict it
clear() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Remove all elements in the cache, but leave the cache in a useable state.
clear() - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Remove all mapping from this cache region.
clear() - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Free resources used by this accessor.
clear() - Method in interface net.sf.ehcache.pool.PoolAccessor
Free resources used by this accessor.
clear() - Method in class net.sf.ehcache.store.CacheKeySet
You can't remove from this set, will throw!
clear() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
 
clear() - Method in class net.sf.ehcache.store.disk.ods.FileAllocationTree
Mark this whole file as free
clear() - Method in class net.sf.ehcache.store.LruMemoryStore
Clears any data structures and places it back to its state when it was first created.
clear() - Method in class net.sf.ehcache.util.SetAsList
clearAll() - Method in class net.sf.ehcache.CacheManager
Clears the contents of all caches in the CacheManager, but without removing any caches.
clearAll() - Method in class net.sf.ehcache.management.CacheManager
Clears the contents of all caches in the CacheManager, but without removing any caches.
clearAll() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Clears the contents of all caches in the CacheManager, but without removing any caches.
clearAll() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Clears the contents of all caches in the CacheManager, but without removing any caches.
clearAll() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Clears the contents of all caches in the CacheManager, but without removing any caches.
clearAllStartingWith(String) - Method in class net.sf.ehcache.CacheManager
Clears the contents of all caches in the CacheManager with a name starting with the prefix, but without removing them.
clearCounters() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Clears all event counters
clearOnFlush - Variable in class net.sf.ehcache.config.CacheConfiguration
Sets whether the MemoryStore should be cleared when flush() is called on the cache - true by default.
clearOnFlush(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets whether the MemoryStore should be cleared when flush() is called on the cache - true by default.
clearStatistics() - Method in class net.sf.ehcache.Cache
Resets statistics counters back to 0.
clearStatistics() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Resets statistics counters back to 0.
clearStatistics() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Resets statistics counters back to 0.
clearStatistics() - Method in interface net.sf.ehcache.Ehcache
Resets statistics counters back to 0.
clearStatistics() - Method in class net.sf.ehcache.management.CacheStatistics
Clears the statistic counters to 0 for the associated Cache.
clearStatistics() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Clears the statistic counters to 0 for the associated Cache.
clearStatistics() - Method in class net.sf.ehcache.management.sampled.SampledCache
Clear both sampled and cumulative statistics
clearStatistics() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Clears statistics of all caches for the associated cacheManager
clearStatistics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Clears statistics of all caches for the associated cacheManager
clearStatistics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Clear both sampled and cumulative statistics
clearStatistics() - Method in class net.sf.ehcache.Statistics
Clears the statistic counters to 0 for the associated Cache.
clearStatistics() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Clears statistics of this cache
clearStatistics() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Clear existing statistics
clearStatistics() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Clears statistics of this cache
clearStatistics() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Clears statistics of this cache
clearStatistics() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Clears statistics of this cache
clearStatistics() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Clears sampled statistics for this cache
clearStatistics() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Clears sampled statistics for this cache
clearStatistics() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Clears the collected statistics.
clearStatistics() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Clears sampled statistics for this cache
clearStats() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Clears current statistics, resets all counters to zero
clearStats() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Clears statistics, resets all counters to zero
clearStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Clears current statistics, resets all counters to zero
clearStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Clears current statistics, resets all counters to zero
clearStats() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Clears statistics, resets all counters to zero
clearStats() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Clears statistics, resets all counters to zero
clearTryLock() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Clear the state of the soft lock after a tryLock() call succeeded.
clearTryLock() - Method in interface net.sf.ehcache.transaction.SoftLock
Clear the state of the soft lock after a tryLock() call succeeded.
CLOCK - Static variable in class net.sf.ehcache.store.MemoryStoreEvictionPolicy
FIFO - first in first out, the oldest element by creation time.
clone() - Method in interface net.sf.ehcache.bootstrap.BootstrapCacheLoader
Clones the loader
clone() - Method in class net.sf.ehcache.Cache
Clones a cache.
clone() - Method in class net.sf.ehcache.config.CacheConfiguration
Clones this object, following the usual contract.
clone() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Clones this object, following the usual contract.
clone() - Method in class net.sf.ehcache.config.FactoryConfiguration
Clones this object, following the usual contract.
clone() - Method in class net.sf.ehcache.config.NonstopConfiguration
clone() - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Clones this object, following the usual contract.
clone() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Clones this object, following the usual contract.
clone() - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
clone() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Clones a cache.
clone() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Clones a cache.
clone() - Method in class net.sf.ehcache.DefaultElementEvictionData
Creates a clone of the eviction data
clone() - Method in class net.sf.ehcache.distribution.RMIAsynchronousCacheReplicator
Creates a clone of this listener.
clone() - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Clones this loader
clone() - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Creates a clone of this listener.
clone() - Method in interface net.sf.ehcache.Ehcache
Clones a cache.
clone() - Method in class net.sf.ehcache.Element
Clones an Element.
clone() - Method in interface net.sf.ehcache.ElementEvictionData
Creates a clone of the eviction data
clone() - Method in interface net.sf.ehcache.event.CacheEventListener
Creates a clone of this listener.
clone() - Method in class net.sf.ehcache.event.CacheEventListenerAdapter
Creates a clone of this listener.
clone() - Method in class net.sf.ehcache.event.NonstopCacheEventListener
Creates a clone of this listener.
clone() - Method in class net.sf.ehcache.event.TerracottaCacheEventReplication
Creates a clone of this listener.
clone(Ehcache) - Method in interface net.sf.ehcache.extension.CacheExtension
Creates a clone of this extension.
clone(Ehcache) - Method in interface net.sf.ehcache.loader.CacheLoader
Creates a clone of this extension.
clone() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Creates a clone of this listener.
clone() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Creates a clone of this listener.
clone() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Creates a clone of this listener.
clone() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
clone() - Method in class net.sf.ehcache.store.DiskStoreBootstrapCacheLoader
Clones the loader
clone() - Method in class net.sf.ehcache.store.MemoryLimitedCacheLoader
Clones the loader
clone() - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Clones the loader
clone(Ehcache) - Method in class net.sf.ehcache.writer.AbstractCacheWriter
Creates a clone of this writer.
clone(Ehcache) - Method in interface net.sf.ehcache.writer.CacheWriter
Creates a clone of this writer.
CLUSTER_COHERENT - Static variable in interface net.sf.ehcache.store.Store
clusterCoherent property
clusterCoherent(boolean) - Method in class net.sf.ehcache.Cache
Inform of cluster coherence.
clusterCoherent(boolean) - Method in interface net.sf.ehcache.store.StoreListener
Inform of cluster coherence.
clustered(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
ClusteredInstanceFactory - Interface in net.sf.ehcache.terracotta
Factory for creating clustered instances
ClusteredInstanceFactoryWrapper - Class in net.sf.ehcache.terracotta
A ClusteredInstanceFactory implementation that delegates all operations to an underlying delegate except for the following operations: ClusteredInstanceFactoryWrapper.getTopology() : Delegates to the TerracottaClient.getCacheCluster()
ClusteredInstanceFactoryWrapper(TerracottaClient, ClusteredInstanceFactory) - Constructor for class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Constructor accepting the TerracottaClient and the actual factory
ClusterNode - Interface in net.sf.ehcache.cluster
Provides information about a node in a cache cluster.
clusterOffline(ClusterNode) - Method in interface net.sf.ehcache.cluster.ClusterTopologyListener
This node has lost contact (possibly temporarily) with the cluster and cannot execute clustered operations
clusterOnline(ClusterNode) - Method in interface net.sf.ehcache.cluster.ClusterTopologyListener
This node has established contact with the cluster and can execute clustered operations.
ClusterOperation<V> - Interface in net.sf.ehcache.constructs.nonstop
Interface for executing clustered operations (that can potentially get stuck)
ClusterOperationCallable<V> - Interface in net.sf.ehcache.constructs.nonstop
A Callable that is used to execute ClusterOperation
clusterRejoinComplete() - Method in interface net.sf.ehcache.terracotta.TerracottaClientRejoinListener
The Terracotta Client has rejoined the cluster.
clusterRejoined(ClusterNode, ClusterNode) - Method in interface net.sf.ehcache.cluster.ClusterTopologyListener
This node lost contact and rejoined the cluster again.
clusterRejoined() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Called when rejoin has happened for this store
clusterRejoined() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Called when rejoin has happened for this store
clusterRejoined() - Method in class net.sf.ehcache.constructs.nonstop.store.RejoinAwareBlockingOperation
Called when cluster rejoin happens
clusterRejoined() - Method in interface net.sf.ehcache.constructs.nonstop.store.RejoinAwareNonstopStore
Called when rejoin has happened for this store
clusterRejoinStarted() - Method in interface net.sf.ehcache.terracotta.TerracottaClientRejoinListener
The Terracotta Client has rejoined the cluster.
ClusterScheme - Enum in net.sf.ehcache.cluster
Lists support cluster schemes (may not include all possible schemes).
ClusterSchemeNotAvailableException - Exception in net.sf.ehcache.cluster
Exception type that is thrown when requesting for a certain type of ClusterScheme and its not available.
ClusterSchemeNotAvailableException(ClusterScheme) - Constructor for exception net.sf.ehcache.cluster.ClusterSchemeNotAvailableException
Constructor accepting the ClusterScheme that is unavailable
ClusterSchemeNotAvailableException(ClusterScheme, String, Throwable) - Constructor for exception net.sf.ehcache.cluster.ClusterSchemeNotAvailableException
Constructor accepting the ClusterScheme that is unavailable, message and root cause
ClusterSchemeNotAvailableException(ClusterScheme, String) - Constructor for exception net.sf.ehcache.cluster.ClusterSchemeNotAvailableException
Constructor accepting the ClusterScheme that is unavailable and message
ClusterSchemeNotAvailableException(ClusterScheme, Throwable) - Constructor for exception net.sf.ehcache.cluster.ClusterSchemeNotAvailableException
Constructor accepting the ClusterScheme that is unavailable and root cause
ClusterTopologyListener - Interface in net.sf.ehcache.cluster
A listener for cluster topology events
CoalesceKeysFilter - Class in net.sf.ehcache.writer.writebehind
Filters the operations by only retaining the latest operations for a given key.
CoalesceKeysFilter() - Constructor for class net.sf.ehcache.writer.writebehind.CoalesceKeysFilter
 
coherent(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Deprecated. since 2.4 Use TerracottaConfiguration.consistency(Consistency) instead
coherentReads(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
collectAllSoftLocksForTransactionID(TransactionID) - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockFactoryImpl
Get a the soft locks of the specified transaction ID
collectAllSoftLocksForTransactionID(TransactionID) - Method in interface net.sf.ehcache.transaction.SoftLockFactory
Get a the soft locks of the specified transaction ID
collectExpiredTransactionIDs() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockFactoryImpl
Get a Set of TransactionIDs for which the soft locks have expired
collectExpiredTransactionIDs() - Method in interface net.sf.ehcache.transaction.SoftLockFactory
Get a Set of TransactionIDs for which the soft locks have expired
CollectionStats - Class in net.sf.ehcache.hibernate.management.impl
CollectionStats
CollectionStats(String) - Constructor for class net.sf.ehcache.hibernate.management.impl.CollectionStats
 
CollectionStats(String, CollectionStatistics) - Constructor for class net.sf.ehcache.hibernate.management.impl.CollectionStats
 
CollectionStats(CompositeData) - Constructor for class net.sf.ehcache.hibernate.management.impl.CollectionStats
 
CombinationSizeOfFilter - Class in net.sf.ehcache.pool.sizeof.filter
Filter combining multiple filters
CombinationSizeOfFilter(SizeOfFilter...) - Constructor for class net.sf.ehcache.pool.sizeof.filter.CombinationSizeOfFilter
Constructs a filter combining multiple ones
Command - Interface in net.sf.ehcache.transaction.xa.commands
 
commit(boolean) - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Commit all work done in the context and release all registered soft locks
commit(Xid, boolean) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
commit() - Method in class net.sf.ehcache.TransactionController
Commit the transaction bound to the current thread
commit(boolean) - Method in class net.sf.ehcache.TransactionController
Commit the transaction bound to the current thread, ignoring if the transaction timed out
commitInternal(Xid, boolean) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
The commit implementation
commitTransactionIfNeeded(Ehcache) - Static method in class net.sf.ehcache.util.CacheTransactionHelper
Commit a transaction previously begun on the current thread if the cache is configured as transactional, otherwise this method does nothing.
ComparableValue - Class in net.sf.ehcache.search.expression
Abstract base class for criteria involving Comparable values
ComparableValue(String, Object) - Constructor for class net.sf.ehcache.search.expression.ComparableValue
Constructor
ComparableValue(String, AttributeType) - Constructor for class net.sf.ehcache.search.expression.ComparableValue
Constructor
comparator() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
compare(Result, Result) - Method in class net.sf.ehcache.search.impl.OrderComparator
compare(Element, Element) - Method in class net.sf.ehcache.store.FifoPolicy
Compares the desirableness for eviction of two elements Compares hit counts.
compare(Element, Element) - Method in class net.sf.ehcache.store.LfuPolicy
Compares the desirableness for eviction of two elements Compares hit counts.
compare(Element, Element) - Method in class net.sf.ehcache.store.LruPolicy
Compares the desirableness for eviction of two elements Compares hit counts.
compare(Element, Element) - Method in interface net.sf.ehcache.store.Policy
Compares the desirableness for eviction of two elements
compareTo(E) - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Compare this node to the supplied 'data' object.
compareTo(Comparable) - Method in class net.sf.ehcache.store.disk.ods.Region
Compare this node to the supplied 'data' object.
compressionEnabled(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
concurrency(int) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
ConcurrencyUtil - Class in net.sf.ehcache.concurrent
Various bits of black magic garnered from experts on the [email protected] mailing list.
ConfigError - Class in net.sf.ehcache.config
Represents a config error
ConfigError(String) - Constructor for class net.sf.ehcache.config.ConfigError
Constructor
ConfigurableRMIClientSocketFactory - Class in net.sf.ehcache.distribution
Default socket timeouts are unlikely to be suitable for cache replication.
ConfigurableRMIClientSocketFactory(Integer) - Constructor for class net.sf.ehcache.distribution.ConfigurableRMIClientSocketFactory
Construct a new socket factory with the given timeout.
Configuration - Class in net.sf.ehcache.config
A bean, used by BeanUtils, to set configuration from an XML configuration file.
Configuration() - Constructor for class net.sf.ehcache.config.Configuration
Empty constructor, which is used by ConfigurationFactory, and can be also used programmatically.
Configuration.Monitoring - Enum in net.sf.ehcache.config
Represents whether monitoring should be enabled or not.
Configuration.RuntimeCfg - Class in net.sf.ehcache.config
Runtime configuration as being used by the CacheManager
Configuration.RuntimeCfg(CacheManager, String) - Constructor for class net.sf.ehcache.config.Configuration.RuntimeCfg
Constructor
ConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
Element representing the Configuration.
ConfigurationElement(Configuration) - Constructor for class net.sf.ehcache.config.generator.model.elements.ConfigurationElement
Constructor accepting the Configuration.
ConfigurationElement(CacheManager) - Constructor for class net.sf.ehcache.config.generator.model.elements.ConfigurationElement
Constructor accepting the CacheManager.
ConfigurationFactory - Class in net.sf.ehcache.config
A utility class which configures beans from XML, using reflection.
ConfigurationGenerator - Class in net.sf.ehcache.config.generator
Deprecated. Use ConfigurationUtil.generateCacheManagerConfigurationText(Configuration) or ConfigurationUtil#generateCacheConfigurationText(CacheConfiguration) instead
ConfigurationGenerator() - Constructor for class net.sf.ehcache.config.generator.ConfigurationGenerator
Deprecated.  
ConfigurationHelper - Class in net.sf.ehcache.config
The configuration for ehcache.
ConfigurationHelper(CacheManager, Configuration) - Constructor for class net.sf.ehcache.config.ConfigurationHelper
Only Constructor
ConfigurationSource - Class in net.sf.ehcache.config.generator
Class encapsulating the source of configuration for a cache manager

ConfigurationSource() - Constructor for class net.sf.ehcache.config.generator.ConfigurationSource
protected constructor
ConfigurationUtil - Class in net.sf.ehcache.config.generator
Utility class with static methods for generating configuration texts in different ways based on input

ConfigurationUtil() - Constructor for class net.sf.ehcache.config.generator.ConfigurationUtil
 
consistency(TerracottaConfiguration.Consistency) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Setter for consistency, returns this instance
constructExtractor() - Method in class net.sf.ehcache.config.SearchAttribute
Construct the extractor for this attribute configuration
contains(Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
Returns true if this region contains data for the given key.
contains(Object) - Method in class net.sf.ehcache.store.CacheKeySet
contains(Object) - Method in class net.sf.ehcache.util.LargeCollection
contains(Object) - Method in class net.sf.ehcache.util.SetAsList
containsAll(Collection<?>) - Method in class net.sf.ehcache.store.CacheKeySet
containsAll(Collection<?>) - Method in class net.sf.ehcache.util.SetAsList
containsKey(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.store.LruMemoryStore
An unsynchronized check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.store.MemoryStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.store.NullStore
A check to see if a key is in the Store.
containsKey(Object) - Method in interface net.sf.ehcache.store.Store
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
A check to see if a key is in the Store.
containsKey(Object) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
A check to see if a key is in the Store.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.store.LruMemoryStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.store.MemoryStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.store.NullStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in interface net.sf.ehcache.store.Store
A check to see if a key is in the Store and is currently held in memory.
containsKeyInMemory(Object) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
A check to see if a key is in the Store and is currently held in memory.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.store.LruMemoryStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.store.MemoryStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.store.NullStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in interface net.sf.ehcache.store.Store
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOffHeap(Object) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
A check to see if a key is in the Store and is currently held off-heap.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.store.LruMemoryStore
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.store.MemoryStore
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.store.NullStore
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in interface net.sf.ehcache.store.Store
A check to see if a key is in the Store and is currently held on disk.
containsKeyOnDisk(Object) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
A check to see if a key is in the Store and is currently held on disk.
contextDestroyed(ServletContextEvent) - Method in class net.sf.ehcache.constructs.web.ShutdownListener
Notification that the servlet context is about to be shut down.
contextInitialized(ServletContextEvent) - Method in class net.sf.ehcache.constructs.web.ShutdownListener
Notification that the web application is ready to process requests.
contiguous() - Method in class net.sf.ehcache.store.disk.ods.Region
Return the size of the largest region linked from this node.
convert(Object) - Method in class net.sf.ehcache.writer.writebehind.CastingOperationConverter
Convert an arbitrary object
convert(Object) - Method in interface net.sf.ehcache.writer.writebehind.OperationConverter
Convert an arbitrary object
convertIntToStatus(int) - Static method in class net.sf.ehcache.Status
 
convertTimeToInt(long) - Static method in class net.sf.ehcache.util.TimeUtil
Converts a long seconds value to an int seconds value and takes into account overflow from the downcast by switching to Integer.MAX_VALUE.
copy() - Method in class net.sf.ehcache.config.CopyStrategyConfiguration
Make copy of this configuration
copy(T) - Method in interface net.sf.ehcache.store.compound.CopyStrategy
Deprecated. Deep copies some object and returns the copy
copyElementForRead(Element) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Copy element for read operation
copyElementForReadIfNeeded(Element) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Perform copy on read on an element if configured
copyElementForWrite(Element) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Copy element for write operation
copyElementForWriteIfNeeded(Element) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Perform copy on write on an element if configured
copyForRead(Element) - Method in class net.sf.ehcache.store.compound.ImmutableValueElementCopyStrategy
 
copyForRead(Element) - Method in class net.sf.ehcache.store.compound.LegacyCopyStrategyAdapter
Reconstruct an object from its storage-ready copy.
copyForRead(Element) - Method in class net.sf.ehcache.store.compound.NullReadWriteCopyStrategy
Reconstruct an object from its storage-ready copy.
copyForRead(T) - Method in interface net.sf.ehcache.store.compound.ReadWriteCopyStrategy
Reconstruct an object from its storage-ready copy.
copyForRead(Element) - Method in class net.sf.ehcache.store.compound.ReadWriteSerializationCopyStrategy
 
copyForRead(Element) - Method in class net.sf.ehcache.store.compound.SerializationCopyStrategy
 
copyForWrite(Element) - Method in class net.sf.ehcache.store.compound.ImmutableValueElementCopyStrategy
 
copyForWrite(Element) - Method in class net.sf.ehcache.store.compound.LegacyCopyStrategyAdapter
Deep copies some object and returns an internal storage-ready copy
copyForWrite(Element) - Method in class net.sf.ehcache.store.compound.NullReadWriteCopyStrategy
Deep copies some object and returns an internal storage-ready copy
copyForWrite(T) - Method in interface net.sf.ehcache.store.compound.ReadWriteCopyStrategy
Deep copies some object and returns an internal storage-ready copy
copyForWrite(Element) - Method in class net.sf.ehcache.store.compound.ReadWriteSerializationCopyStrategy
 
copyForWrite(Element) - Method in class net.sf.ehcache.store.compound.SerializationCopyStrategy
 
copyOnRead(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Whether the Cache should copy elements it returns
copyOnRead(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
copyOnWrite(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Whether the Cache should copy elements it gets
CopyStrategy - Interface in net.sf.ehcache.store.compound
Deprecated. replaced by ReadWriteCopyStrategy
copyStrategy - Variable in class net.sf.ehcache.transaction.AbstractTransactionStore
The copy strategy for this store
CopyStrategyConfiguration - Class in net.sf.ehcache.config
 
CopyStrategyConfiguration() - Constructor for class net.sf.ehcache.config.CopyStrategyConfiguration
 
CopyStrategyConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the CopyStrategyConfiguration
CopyStrategyConfigurationElement(NodeElement, CopyStrategyConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.CopyStrategyConfigurationElement
Constructor accepting the parent and the CopyStrategyConfiguration
copyWith(int, boolean) - Method in class net.sf.ehcache.pool.impl.DefaultSizeOfEngine
Make a copy of the SizeOf engine, preserving all of its internal state but overriding the specified parameters
copyWith(int, boolean) - Method in interface net.sf.ehcache.pool.SizeOfEngine
Make a copy of the SizeOf engine, preserving all of its internal state but overriding the specified parameters
copyWith(int, boolean) - Method in class net.sf.ehcache.store.disk.DiskSizeOfEngine
Make a copy of the SizeOf engine, preserving all of its internal state but overriding the specified parameters
count() - Static method in class net.sf.ehcache.search.aggregator.Aggregators
Construct a counting aggregator
Count - Class in net.sf.ehcache.search.aggregator
Counts the number of results
Count() - Constructor for class net.sf.ehcache.search.aggregator.Count
 
count() - Method in class net.sf.ehcache.search.Attribute
Request a count aggregation of this attribute
count - Variable in class net.sf.ehcache.store.disk.Segment
Count of elements in the map.
Counter - Interface in net.sf.ehcache.util.counter
A simple counter
CounterConfig - Class in net.sf.ehcache.util.counter
Config for a simple Counter
CounterConfig(long) - Constructor for class net.sf.ehcache.util.counter.CounterConfig
Creates a config with the initial value
CounterImpl - Class in net.sf.ehcache.util.counter
A simple counter implementation
CounterImpl() - Constructor for class net.sf.ehcache.util.counter.CounterImpl
Default Constructor
CounterImpl(long) - Constructor for class net.sf.ehcache.util.counter.CounterImpl
Constructor with initial value
CounterManager - Interface in net.sf.ehcache.util.counter
A Counter Manager that accepts a config to create counters.
CounterManagerImpl - Class in net.sf.ehcache.util.counter
An implementation of a CounterManager.
CounterManagerImpl(FailSafeTimer) - Constructor for class net.sf.ehcache.util.counter.CounterManagerImpl
Constructor that accepts a timer that will be used for scheduling sampled counter if any is created
CountingThreadFactory - Class in net.sf.ehcache.constructs.nonstop.util
A custom ThreadFactory that maintains a count of how many threads this factory has created
CountingThreadFactory(ThreadFactory) - Constructor for class net.sf.ehcache.constructs.nonstop.util.CountingThreadFactory
Constructor accepting the actual thread factory that will create the threads
countSize(T) - Method in class net.sf.ehcache.pool.impl.AbstractBalancedAccessEvictor
Return the number of mappings in the supplied store.
countSize(PoolableStore) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnDiskPoolEvictor
Return the number of mappings in the supplied store.
countSize(PoolableStore) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnHeapPoolEvictor
Return the number of mappings in the supplied store.
create() - Static method in class net.sf.ehcache.CacheManager
A factory method to create a singleton CacheManager with default config, or return it if it exists.
create(String) - Static method in class net.sf.ehcache.CacheManager
A factory method to create a singleton CacheManager with a specified configuration.
create(URL) - Static method in class net.sf.ehcache.CacheManager
A factory method to create a singleton CacheManager from an URL.
create(InputStream) - Static method in class net.sf.ehcache.CacheManager
A factory method to create a singleton CacheManager from a java.io.InputStream.
create(Configuration) - Static method in class net.sf.ehcache.CacheManager
A factory method to create a singleton CacheManager from a net.sf.ehcache.config.Configuration.
create(Element) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Create a disk substitute for an element
create(Ehcache, String, Pool, Pool) - Static method in class net.sf.ehcache.store.disk.DiskStore
Creates a persitent-to-disk store for the given cache, using the given disk path.
create(Cache, String) - Static method in class net.sf.ehcache.store.disk.DiskStore
Creates a persitent-to-disk store for the given cache, using the given disk path.
create(Ehcache, String, Pool, Pool) - Static method in class net.sf.ehcache.store.DiskBackedMemoryStore
Create a DiskBackedMemoryStore instance
create(Ehcache, Pool) - Static method in class net.sf.ehcache.store.MemoryOnlyStore
Create an instance of MemoryStore
create(Ehcache, Pool) - Static method in class net.sf.ehcache.store.MemoryStore
A factory method to create a MemoryStore.
create(Ehcache, Pool) - Static method in class net.sf.ehcache.store.NotifyingMemoryStore
A factory method to create a MemoryStore.
create() - Static method in class net.sf.ehcache.store.NullStore
Create a new NullStore instance.
createAutomaticallyConfiguredCachePeerProvider(CacheManager, Properties) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory
peerDiscovery=automatic, multicastGroupAddress=230.0.0.1, multicastGroupPort=4446, multicastPacketTimeToLive=255
createBatchOperation(List<SingleOperation>) - Method in class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Creates a batch operation that corresponds to the operation type of this single operation.
createBatchOperation(List<SingleOperation>) - Method in interface net.sf.ehcache.writer.writebehind.operations.SingleOperation
Creates a batch operation that corresponds to the operation type of this single operation.
createBatchOperation(List<SingleOperation>) - Method in class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Creates a batch operation that corresponds to the operation type of this single operation.
createBootstrapCacheLoader(Properties) - Method in class net.sf.ehcache.bootstrap.BootstrapCacheLoaderFactory
Create a BootstrapCacheLoader
createBootstrapCacheLoader(Properties) - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoaderFactory
Create a BootstrapCacheLoader
createBootstrapCacheLoader(Properties) - Method in class net.sf.ehcache.store.DiskStoreBootstrapCacheLoaderFactory
Create a BootstrapCacheLoader
createBootstrapCacheLoader(Properties) - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoaderFactory
 
createCacheDecorators(Ehcache) - Method in class net.sf.ehcache.config.ConfigurationHelper
Creates decorated ehcaches for the cache, if any configured in ehcache.xml
createCacheEventListener(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Create a CacheEventListener which is also a CacheReplicator.
createCacheEventListener(Properties) - Method in class net.sf.ehcache.event.CacheEventListenerFactory
Create a CacheEventListener
createCacheEventListener(Properties) - Method in class net.sf.ehcache.event.TerracottaCacheEventReplicationFactory
Create a CacheEventListener
createCacheExceptionHandler(CacheConfiguration.CacheExceptionHandlerFactoryConfiguration) - Static method in class net.sf.ehcache.config.ConfigurationHelper
Tries to create a CacheLoader from the configuration using the factory specified.
createCacheExtension(Ehcache, Properties) - Method in class net.sf.ehcache.extension.CacheExtensionFactory
 
createCacheLoader(Ehcache, Properties) - Method in class net.sf.ehcache.loader.CacheLoaderFactory
Creates a CacheLoader using the Ehcache configuration mechanism at the time the associated cache is created.
createCacheManagerEventListener(CacheManager) - Method in class net.sf.ehcache.config.ConfigurationHelper
Tries to load the class specified.
createCacheManagerEventListener(CacheManager, Properties) - Method in class net.sf.ehcache.event.CacheManagerEventListenerFactory
Create a CacheEventListener
createCachePeerListener(CacheManager, Properties) - Method in class net.sf.ehcache.distribution.CacheManagerPeerListenerFactory
Creates a peer provider.
createCachePeerListener(CacheManager, Properties) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListenerFactory
 
createCachePeerListeners() - Method in class net.sf.ehcache.config.ConfigurationHelper
Tries to load the class specified otherwise defaults to null
createCachePeerProvider(CacheManager, Properties) - Method in class net.sf.ehcache.distribution.CacheManagerPeerProviderFactory
Create a peer provider.
createCachePeerProvider(CacheManager, Properties) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory
 
createCachePeerProviders() - Method in class net.sf.ehcache.config.ConfigurationHelper
Tries to load the class specified otherwise defaults to null
createCaches() - Method in class net.sf.ehcache.config.ConfigurationHelper
Creates unitialised caches for each cache configuration found
createCacheWriter(Ehcache, Properties) - Method in class net.sf.ehcache.writer.CacheWriterFactory
Creates a CacheWriter using the Ehcache configuration mechanism at the time the associated cache is created.
createClusteredInstanceFactory(Map<String, CacheConfiguration>) - Method in class net.sf.ehcache.terracotta.TerracottaClient
Returns true if the clusteredInstanceFactory was created, otherwise returns false.
createCollectionRegionAccessStrategy(EhcacheCollectionRegion, AccessType) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAccessStrategyFactory
Create CollectionRegionAccessStrategy for the input EhcacheCollectionRegion and AccessType
createCollectionRegionAccessStrategy(EhcacheCollectionRegion, AccessType) - Method in interface net.sf.ehcache.hibernate.strategy.EhcacheAccessStrategyFactory
Create CollectionRegionAccessStrategy for the input EhcacheCollectionRegion and AccessType
createCollectionRegionAccessStrategy(EhcacheCollectionRegion, AccessType) - Method in class net.sf.ehcache.hibernate.strategy.EhcacheAccessStrategyFactoryImpl
Create CollectionRegionAccessStrategy for the input EhcacheCollectionRegion and AccessType
createConfiguration() - Method in class net.sf.ehcache.config.generator.ConfigurationSource
Abstract method used for creating a Configuration based on the source
createCounter() - Method in class net.sf.ehcache.util.counter.CounterConfig
Creates and returns a Counter based on the initial value
createCounter(CounterConfig) - Method in interface net.sf.ehcache.util.counter.CounterManager
Creates a Counter based on tha passed config
createCounter(CounterConfig) - Method in class net.sf.ehcache.util.counter.CounterManagerImpl
Creates a Counter based on tha passed config
createCounter() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterConfig
Creates and returns a Counter based on the initial value
createCounter() - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterConfig
Creates and returns a Counter based on the initial value
created(Object) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Returns true if this factory created the given object.
createDecoratedEhcache(Ehcache, Properties) - Method in class net.sf.ehcache.constructs.CacheDecoratorFactory
Creates a decorated Ehcache using the properties specified for configuring the decorator.
createDefaultCache() - Method in class net.sf.ehcache.config.ConfigurationHelper
 
createDefaultCacheDecorators(Ehcache, CacheConfiguration) - Static method in class net.sf.ehcache.config.ConfigurationHelper
Creates default cache decorators specified in the default cache configuration if any
createDefaultDecoratedEhcache(Ehcache, Properties) - Method in class net.sf.ehcache.constructs.CacheDecoratorFactory
This method is called when the factory is specified for the defaultCache in the config.
createDiskStore() - Method in class net.sf.ehcache.Cache
Creates a disk store when either: overflowToDisk is enabled diskPersistent is enabled
createElement(ClassLoader) - Method in interface net.sf.ehcache.event.RegisteredEventListeners.ElementCreationCallback
Materialize the relevant element in the given classloader
createEntityRegionAccessStrategy(EhcacheEntityRegion, AccessType) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAccessStrategyFactory
Create EntityRegionAccessStrategy for the input EhcacheEntityRegion and AccessType
createEntityRegionAccessStrategy(EhcacheEntityRegion, AccessType) - Method in interface net.sf.ehcache.hibernate.strategy.EhcacheAccessStrategyFactory
Create EntityRegionAccessStrategy for the input EhcacheEntityRegion and AccessType
createEntityRegionAccessStrategy(EhcacheEntityRegion, AccessType) - Method in class net.sf.ehcache.hibernate.strategy.EhcacheAccessStrategyFactoryImpl
Create EntityRegionAccessStrategy for the input EhcacheEntityRegion and AccessType
createEntry(Object) - Method in interface net.sf.ehcache.constructs.blocking.CacheEntryFactory
Creates the cacheEntry for the given cache key.
createEventReplicator(Ehcache) - Method in interface net.sf.ehcache.terracotta.ClusteredInstanceFactory
Create a replicator for the cache events of a given cache
createEventReplicator(Ehcache) - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Create a replicator for the cache events of a given cache
createExceptionHandler(Properties) - Method in class net.sf.ehcache.exceptionhandler.CacheExceptionHandlerFactory
Create an CacheExceptionHandler
createInstance() - Method in interface net.sf.ehcache.search.aggregator.Aggregator
Create an instance of this aggregator.
createManuallyConfiguredCachePeerProvider(Properties) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory
peerDiscovery=manual, rmiUrls=//hostname:port/cacheName //hostname:port/cacheName //hostname:port/cacheName
createMBeanRegistrationProvider(Configuration) - Method in interface net.sf.ehcache.management.provider.MBeanRegistrationProviderFactory
Factory Method for creating MBeanRegistrationProvider
createMBeanRegistrationProvider(Configuration) - Method in class net.sf.ehcache.management.provider.MBeanRegistrationProviderFactoryImpl
Factory Method for creating MBeanRegistrationProvider
createNewInstance(String) - Static method in class net.sf.ehcache.util.ClassLoaderUtil
Creates a new class instance.
createNewInstance(String, Class[], Object[]) - Static method in class net.sf.ehcache.util.ClassLoaderUtil
Creates a new class instance and passes args to the constructor call.
createNonstopTimeoutBehaviorStore(NonstopActiveDelegateHolder) - Method in interface net.sf.ehcache.constructs.nonstop.NonstopTimeoutBehaviorFactory
Create the NonstopStore to be used for timeout
createPoolAccessor(T, int, boolean) - Method in class net.sf.ehcache.pool.impl.AbstractPool
Return a PoolAccessor whose consumption is tracked by this pool, using a default SizeOf engine.
createPoolAccessor(PoolableStore, SizeOfEngine) - Method in class net.sf.ehcache.pool.impl.BoundedPool
Return a PoolAccessor whose consumption is tracked by this pool, using a specific SizeOf engine.
createPoolAccessor(PoolableStore, SizeOfEngine) - Method in class net.sf.ehcache.pool.impl.StrictlyBoundedPool
Return a PoolAccessor whose consumption is tracked by this pool, using a specific SizeOf engine.
createPoolAccessor(PoolableStore, int, boolean) - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Return a PoolAccessor whose consumption is tracked by this pool, using a default SizeOf engine.
createPoolAccessor(PoolableStore, SizeOfEngine) - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Return a PoolAccessor whose consumption is tracked by this pool, using a specific SizeOf engine.
createPoolAccessor(T, int, boolean) - Method in interface net.sf.ehcache.pool.Pool
Return a PoolAccessor whose consumption is tracked by this pool, using a default SizeOf engine.
createPoolAccessor(T, SizeOfEngine) - Method in interface net.sf.ehcache.pool.Pool
Return a PoolAccessor whose consumption is tracked by this pool, using a specific SizeOf engine.
createProxy(Ehcache) - Static method in class net.sf.ehcache.exceptionhandler.ExceptionHandlingDynamicCacheProxy
A simple factory method to hide the messiness of creating the proxy from clients.
createQuery() - Method in class net.sf.ehcache.Cache
Create a new query builder for this cache
createQuery() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Create a new query builder for this cache
createQuery() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Create a new query builder for this cache
createQuery() - Method in interface net.sf.ehcache.Ehcache
Create a new query builder for this cache
createSegment(int, float) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
createSocket(String, int) - Method in class net.sf.ehcache.distribution.ConfigurableRMIClientSocketFactory
Create a client socket connected to the specified host and port.
createSoftLock(TransactionID, Object, Element, Element, boolean) - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockFactoryImpl
Create a new, unlocked soft lock
createSoftLock(TransactionID, Object, Element, Element, boolean) - Method in interface net.sf.ehcache.transaction.SoftLockFactory
Create a new, unlocked soft lock
createStore(Ehcache) - Method in interface net.sf.ehcache.terracotta.ClusteredInstanceFactory
Create a Store instance for the given cache
createStore(Ehcache) - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Create a Store instance for the given cache
createStripedReadWriteLock() - Method in class net.sf.ehcache.store.disk.DiskStore
Will create a StripedReadWriteLock always using the same spreading function
createStripedReadWriteLock() - Method in interface net.sf.ehcache.store.StripedReadWriteLockProvider
Will create a StripedReadWriteLock always using the same spreading function
createTerracottaEventReplicator(Ehcache) - Method in class net.sf.ehcache.CacheManager
Create/access the appropriate clustered cache event replicator for the given cache
createTerracottaStore(Ehcache) - Method in class net.sf.ehcache.CacheManager
Create/access the appropriate terracotta clustered store for the given cache
createTerracottaWriteBehind(Ehcache) - Method in class net.sf.ehcache.CacheManager
Create/access the appropriate clustered write behind queue for the given cache
createTransactionContext() - Method in interface net.sf.ehcache.transaction.xa.EhcacheXAResource
Obtain the already associated XATransactionContext with the current Transaction, or create a new one should none be there yet.
createTransactionContext() - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
Obtain the already associated XATransactionContext with the current Transaction, or create a new one should none be there yet.
createTransactionID() - Method in class net.sf.ehcache.transaction.DelegatingTransactionIDFactory
Create a unique transaction ID
createTransactionID() - Method in interface net.sf.ehcache.transaction.TransactionIDFactory
Create a unique transaction ID
createTransactionID() - Method in class net.sf.ehcache.transaction.TransactionIDFactoryImpl
Create a unique transaction ID
createTransactionIDFactory(String, String) - Method in interface net.sf.ehcache.terracotta.ClusteredInstanceFactory
Create a TransactionIDFactory
createTransactionIDFactory(String, String) - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Create a TransactionIDFactory
createWriteBehind(Ehcache) - Method in interface net.sf.ehcache.terracotta.ClusteredInstanceFactory
Create an WriteBehind instance for the given cache
createWriteBehind(Ehcache) - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Create an WriteBehind instance for the given cache
createWriterManager(Cache) - Method in enum net.sf.ehcache.config.CacheWriterConfiguration.WriteMode
Create a new WriterManager for a particular cache instance
createXidTransactionID(Xid) - Method in class net.sf.ehcache.transaction.DelegatingTransactionIDFactory
Create a transaction ID based on a XID for uniqueness
createXidTransactionID(Xid) - Method in interface net.sf.ehcache.transaction.TransactionIDFactory
Create a transaction ID based on a XID for uniqueness
createXidTransactionID(Xid) - Method in class net.sf.ehcache.transaction.TransactionIDFactoryImpl
Create a transaction ID based on a XID for uniqueness
Criteria - Interface in net.sf.ehcache.search.expression
Criteria interface defines a boolean function that computes a search match result
CURRENT_JVM_INFORMATION - Static variable in enum net.sf.ehcache.pool.sizeof.JvmInformation
The JvmInformation instance representing the current JVM
CUSTOM_TYPE_FACTORY_PROPERTY_NAME - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Property name used to configure the class name of the factory class used by TimeoutBehaviorConfiguration.TimeoutBehaviorType.CUSTOM
CUSTOM_TYPE_NAME - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Type name for TimeoutBehaviorConfiguration.TimeoutBehaviorType.CUSTOM

D

DASH - Static variable in class net.sf.ehcache.constructs.CacheDecoratorFactory
Dash string : "-"
DeadLockException - Exception in net.sf.ehcache.transaction
This exception is thrown when a deadlock between two transactions is detected
DeadLockException(String) - Constructor for exception net.sf.ehcache.transaction.DeadLockException
Create a new DeadLockException
decrement() - Method in interface net.sf.ehcache.util.counter.Counter
Decrement the counter by 1
decrement(long) - Method in interface net.sf.ehcache.util.counter.Counter
Decrement the counter by given amount
decrement() - Method in class net.sf.ehcache.util.counter.CounterImpl
Decrement the counter by 1
decrement(long) - Method in class net.sf.ehcache.util.counter.CounterImpl
Decrement the counter by given amount
decrement(long, long) - Method in interface net.sf.ehcache.util.counter.sampled.SampledRateCounter
Decrements the numerator and denominator by the passed values
decrement(long, long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
Decrements the numerator and denominator by the passed values
decrement() - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
throws UnsupportedOperationException
decrement(long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
throws UnsupportedOperationException
decrementLevel() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Decrement and then return this node's new level.
decrementLevel() - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Decrement and then return this node's new level.
deepSizeOf(int, boolean, Object...) - Method in class net.sf.ehcache.pool.sizeof.SizeOf
Measures the size in memory (heap) of the objects passed in, walking their graph down Any overlap of the graphs being passed in will be recognized and only measured once
DEFAULT_ASYNCHRONOUS_REPLICATION_INTERVAL_MILLIS - Static variable in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
A default for the amount of time the replication thread sleeps after it detects the replicationQueue is empty before checking again.
DEFAULT_ASYNCHRONOUS_REPLICATION_MAXIMUM_BATCH_SIZE - Static variable in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
A default for the maximum number of operations in an RMI message.
DEFAULT_BULK_OP_TIMEOUT_FACTOR - Static variable in class net.sf.ehcache.config.NonstopConfiguration
Default value of timeout multiplication factor for bulk operations like removeAll or size
DEFAULT_CACHE_COHERENT - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Deprecated. since 2.4 Use TerracottaConfiguration.DEFAULT_CONSISTENCY_TYPE instead.
DEFAULT_CACHE_NAME - Static variable in class net.sf.ehcache.Cache
A reserved word for cache names.
DEFAULT_CACHE_WRITER_CONFIGURATION - Static variable in class net.sf.ehcache.config.CacheConfiguration
The default cacheWriterConfiguration
DEFAULT_CACHE_XA - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default xa enabled
DEFAULT_CLEAR_ON_FLUSH - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for clearOnFlush
DEFAULT_CLUSTERED - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default clustered mode
DEFAULT_COHERENT_READS - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default coherent read behavior
DEFAULT_COMPRESSION_ENABLED - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default compression setting
DEFAULT_CONCURRENCY - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default value for concurrency of the internal Store.
DEFAULT_CONSISTENCY_TYPE - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default cache consistency setting
DEFAULT_COPY_ON_READ - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for copyOnRead
DEFAULT_COPY_ON_READ - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default copy on read setting
DEFAULT_COPY_ON_WRITE - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for copyOnRead
DEFAULT_COPY_STRATEGY_CONFIGURATION - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default copyStrategyConfiguration
DEFAULT_DEDICATED_THREAD - Static variable in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
The default on whether to do the snapshot on a dedicated thread or using the CacheManager's ScheduledExecutorService
DEFAULT_DISK_ACCESS_STRIPES - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default number of diskAccessStripes.
DEFAULT_DISK_PERSISTENT - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for diskPersistent
DEFAULT_DYNAMIC_CONFIG - Static variable in class net.sf.ehcache.config.Configuration
Default value for dynamicConfig
DEFAULT_ELEMENT_VALUE_COMPARATOR_CONFIGURATION - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default elementComparatorConfiguration
DEFAULT_ENABLED - Static variable in class net.sf.ehcache.config.NonstopConfiguration
Default value of nonstop attribute
DEFAULT_ETERNAL_VALUE - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default eternal value
DEFAULT_EXPIRY_THREAD_INTERVAL_SECONDS - Static variable in class net.sf.ehcache.Cache
The default interval between runs of the expiry thread.
DEFAULT_EXPIRY_THREAD_INTERVAL_SECONDS - Static variable in class net.sf.ehcache.config.CacheConfiguration
The default interval between runs of the expiry thread.
DEFAULT_IMMEDIATE_TIMEOUT - Static variable in class net.sf.ehcache.config.NonstopConfiguration
Default value of immediateTimeout attribute
DEFAULT_INTERVAL - Static variable in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
The default interval in seconds, between each snapshot
DEFAULT_LOCAL_CACHE_ENABLED - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default value for whether local cache is enabled or not
DEFAULT_LOCAL_KEY_CACHE - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default local key cache status
DEFAULT_LOCAL_KEY_CACHE_SIZE - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default local key cache size
DEFAULT_LOGGING - Static variable in class net.sf.ehcache.config.CacheConfiguration
Logging is off by default.
DEFAULT_MAX_BYTES_OFF_HEAP - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default maxBytesOffHeap value
DEFAULT_MAX_BYTES_OFF_HEAP - Static variable in class net.sf.ehcache.config.Configuration
Default value for maxBytesLocalOffHeap when not explicitly set
DEFAULT_MAX_BYTES_ON_DISK - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default maxBytesOnDisk value
DEFAULT_MAX_BYTES_ON_DISK - Static variable in class net.sf.ehcache.config.Configuration
Default value for maxBytesLocalDisk when not explicitly set
DEFAULT_MAX_BYTES_ON_HEAP - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default maxBytesOnHeap value
DEFAULT_MAX_BYTES_ON_HEAP - Static variable in class net.sf.ehcache.config.Configuration
Default value for maxBytesLocalHeap when not explicitly set
DEFAULT_MAX_DEPTH_EXCEEDED_BEHAVIOR - Static variable in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Default max traversal depth exceeded behavior
DEFAULT_MAX_ELEMENTS_ON_DISK - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for maxElementsOnDisk
DEFAULT_MAX_SIZEOF_DEPTH - Static variable in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Default max traversal depth
DEFAULT_MAX_WRITE_DELAY - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default maximum write delay
DEFAULT_MAXIMUM_CHUNK_SIZE_BYTES - Static variable in class net.sf.ehcache.distribution.RMIBootstrapCacheLoaderFactory
The default maximum serialized size of the elements to request from a remote cache peer during bootstrap.
DEFAULT_MEMORY_STORE_EVICTION_POLICY - Static variable in class net.sf.ehcache.config.CacheConfiguration
The default memory store eviction policy is LRU.
DEFAULT_MIN_WRITE_DELAY - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default minimum write delay
DEFAULT_MONITORING - Static variable in class net.sf.ehcache.config.Configuration
Default value for monitoring
DEFAULT_NAME - Static variable in class net.sf.ehcache.CacheManager
Default name if not specified in the configuration/
DEFAULT_NON_STOP_CONFIGURATION - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default value for NonstopConfiguration
DEFAULT_NOTIFY_LISTENERS_ON_EXCEPTION - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default notifyListenersOnException behavior
DEFAULT_NUMBER_OF_MUTEXES - Static variable in class net.sf.ehcache.concurrent.StripedReadWriteLockSync
The default number of locks to use.
DEFAULT_ORPHAN_EVICTION - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default orphan eviction status
DEFAULT_ORPHAN_EVICTION_PERIOD - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default orphan eviction period
DEFAULT_PROPERTIES - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Default value for properties.
DEFAULT_PROPERTY_SEPARATOR - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Default value for property separator
DEFAULT_RATE_LIMIT_PER_SECOND - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default rate limit per second
DEFAULT_REJOIN_VALUE - Static variable in class net.sf.ehcache.config.TerracottaClientConfiguration
Default value of rejoin attribute
DEFAULT_RETRY_ATTEMPT_DELAY_SECONDS - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default retry attempt delay
DEFAULT_RETRY_ATTEMPTS - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default retry attempts
DEFAULT_SIZEOF_POLICY_CONFIGURATION - Static variable in class net.sf.ehcache.config.Configuration
Default sizeOfPolicy configuration
DEFAULT_SOCKET_TIMEOUT_MILLIS - Static variable in class net.sf.ehcache.distribution.RMICacheManagerPeerListenerFactory
The default timeout for cache replication for a single replication action.
DEFAULT_SPOOL_BUFFER_SIZE - Static variable in class net.sf.ehcache.config.CacheConfiguration
Set a buffer size for the spool of approx 30MB.
DEFAULT_STATISTICS - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for statistics
DEFAULT_STORAGE_STRATEGY - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default setting for storageStrategy
DEFAULT_SYNCHRONOUS_WRITES - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default setting for synchronous-write
DEFAULT_TIMEOUT_BEHAVIOR - Static variable in class net.sf.ehcache.config.NonstopConfiguration
Default value of timeoutBehavior attribute
DEFAULT_TIMEOUT_BEHAVIOR_TYPE - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Default value for timeout behavior
DEFAULT_TIMEOUT_MILLIS - Static variable in class net.sf.ehcache.config.NonstopConfiguration
Default value of timeoutMillis attribute
DEFAULT_TRANSACTION_MANAGER_LOOKUP_CONFIG - Static variable in class net.sf.ehcache.config.Configuration
Default transactionManagerLookupConfiguration
DEFAULT_TRANSACTION_TIMEOUT - Static variable in class net.sf.ehcache.config.Configuration
Default value for defaultTransactionTimeoutInSeconds
DEFAULT_TRANSACTIONAL_MODE - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for transactionalMode
DEFAULT_TTI - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for tti
DEFAULT_TTL - Static variable in class net.sf.ehcache.config.CacheConfiguration
Default value for ttl
DEFAULT_UPDATE_CHECK - Static variable in class net.sf.ehcache.config.Configuration
Default value for updateCheck
DEFAULT_VALUE - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Default value for timeout behavior
DEFAULT_VALUE_MODE - Static variable in class net.sf.ehcache.config.TerracottaConfiguration
Default value mode
DEFAULT_WRITE_BATCH_SIZE - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default write batch size
DEFAULT_WRITE_BATCHING - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default writeBatching behavior
DEFAULT_WRITE_BEHIND_CONCURRENCY - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default concurrency level for write behind
DEFAULT_WRITE_BEHIND_MAX_QUEUE_SIZE - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default max queue size for write behind
DEFAULT_WRITE_COALESCING - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default write coalescing behavior
DEFAULT_WRITE_MODE - Static variable in class net.sf.ehcache.config.CacheWriterConfiguration
Default writeMode
defaultCache(CacheConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder method to set the default cache configuration, this can only be used once.
DefaultCacheConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the CacheConfiguration of the "defaultCache"
DefaultCacheConfigurationElement(NodeElement, Configuration, CacheConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.DefaultCacheConfigurationElement
Constructor accepting the parent and the CacheConfiguration
DefaultElementEvictionData - Class in net.sf.ehcache
Default implementation of the element eviction data storage that just keeps all the data in instance fields in the heap.
DefaultElementEvictionData(long) - Constructor for class net.sf.ehcache.DefaultElementEvictionData
Default constructor initializing the field to their empty values
DefaultElementEvictionData(long, long) - Constructor for class net.sf.ehcache.DefaultElementEvictionData
Constructor allowing custom values for the data fields.
DefaultElementValueComparator - Class in net.sf.ehcache.store
 
DefaultElementValueComparator(CacheConfiguration) - Constructor for class net.sf.ehcache.store.DefaultElementValueComparator
Constructor
DefaultSizeOfEngine - Class in net.sf.ehcache.pool.impl
 
DefaultSizeOfEngine(int, boolean) - Constructor for class net.sf.ehcache.pool.impl.DefaultSizeOfEngine
Creates a default size of engine using the best available sizing algorithm.
DefaultTransactionManagerLookup - Class in net.sf.ehcache.transaction.manager
Default TransactionManagerLookup implementation, that will be used by an initializing Cache should the user have not specified otherwise.
DefaultTransactionManagerLookup() - Constructor for class net.sf.ehcache.transaction.manager.DefaultTransactionManagerLookup
 
defaultTransactionTimeoutInSeconds(int) - Method in class net.sf.ehcache.config.Configuration
Builder to set the default transaction timeout.
defaultValue(String) - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Builder convenience method for setting defaultValue
defaultValue(String) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Builder convenience method for setting defaultValue
defaultValue(boolean) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Same as SimpleNodeAttribute.defaultValue(String) using String.valueOf(defaultValue)
defaultValue(int) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Same as SimpleNodeAttribute.defaultValue(String) using String.valueOf(defaultValue)
defaultValue(Enum) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Same as SimpleNodeAttribute.defaultValue(String) using String.valueOf(defaultValue)
defaultValue(long) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Same as SimpleNodeAttribute.defaultValue(String) using String.valueOf(defaultValue)
DelegatingTransactionIDFactory - Class in net.sf.ehcache.transaction
A TransactionIDFactory implementation with delegates calls to either a clustered or non-clustered factory
DelegatingTransactionIDFactory(TerracottaClient, String) - Constructor for class net.sf.ehcache.transaction.DelegatingTransactionIDFactory
Create a new DelegatingTransactionIDFactory
delete(long) - Method in interface net.sf.ehcache.pool.PoolAccessor
Delete a fixed number of bytes from the pool.
delete() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Deletes the data file for this factory.
delete(CacheEntry) - Method in class net.sf.ehcache.writer.AbstractCacheWriter
Delete the cache entry from the store
delete(CacheEntry) - Method in interface net.sf.ehcache.writer.CacheWriter
Delete the cache entry from the store
delete(CacheEntry) - Method in interface net.sf.ehcache.writer.writebehind.WriteBehind
Add a delete operation for the given cache entry
delete(CacheEntry) - Method in class net.sf.ehcache.writer.writebehind.WriteBehindQueueManager
Add a delete operation for the given cache entry
deleteAll(Collection<CacheEntry>) - Method in class net.sf.ehcache.writer.AbstractCacheWriter
Remove data and keys from the underlying store for the given collection of keys, if present.
deleteAll(Collection<CacheEntry>) - Method in interface net.sf.ehcache.writer.CacheWriter
Remove data and keys from the underlying store for the given collection of keys, if present.
DeleteAllOperation - Class in net.sf.ehcache.writer.writebehind.operations
Implements the delete all operation for write behind
DeleteAllOperation(List<CacheEntry>) - Constructor for class net.sf.ehcache.writer.writebehind.operations.DeleteAllOperation
Create a new delete all operation for the provided list of cache entries
deleteCount - Variable in class net.sf.ehcache.hibernate.management.impl.EntityStats
deleteCount
deleteFile(File) - Static method in class net.sf.ehcache.store.disk.DiskStorageFactory
Attempt to delete the corresponding file and log an error on failure.
DeleteOperation - Class in net.sf.ehcache.writer.writebehind.operations
Implements the delete operation for write behind
DeleteOperation(CacheEntry) - Constructor for class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Create a new delete operation for a particular entry
DeleteOperation(CacheEntry, long) - Constructor for class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Create a new delete operation for a particular entry and creation time
depth() - Method in class net.sf.ehcache.util.CircularLossyQueue
Returns the number of items currently in the queue
deregistered(CacheConfiguration) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates that this listener was removed from the given configuration
deregistered(CacheConfiguration) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates that this listener was removed from the given configuration
deregistered(CacheConfiguration) - Method in class net.sf.ehcache.store.MemoryStore
Indicates that this listener was removed from the given configuration
destroy() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Remove the cache and make it unuseable.
destroy() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
determineHitRatio() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
determineShortName(String) - Static method in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
determineShortName
Direction - Enum in net.sf.ehcache.search
The direction for search result ordering
disableAllOutputBehaviors() - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Disables all output behaviors
disableDynamicFeatures() - Method in class net.sf.ehcache.Cache
Disables dynamic configuration and disable/enable for this cache.
disableDynamicFeatures() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Disables dynamic configuration and disable/enable for this cache.
disableDynamicFeatures() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Disables dynamic configuration and disable/enable for this cache.
disableDynamicFeatures() - Method in interface net.sf.ehcache.Ehcache
Disables dynamic configuration and disable/enable for this cache.
disableOutputBehavior(XMLGeneratorVisitor.OutputBehavior) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Disables one particular XMLGeneratorVisitor.OutputBehavior
disableSampledStatistics() - Method in class net.sf.ehcache.management.sampled.SampledCache
Disables statistics collection
disableSampledStatistics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Disables statistics collection
disableSampledStatistics() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Disable sampled statistics collection
disableStatistics() - Method in class net.sf.ehcache.management.sampled.SampledCache
Disables statistics collection.
disableStatistics() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Disable statistics for each cache contained by cacheManager
disableStatistics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Disable statistics for each cache contained by cacheManager
disableStatistics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Disables statistics collection.
disableStats() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Disables statistics collection
disableStats() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Disables statistics collection
disableStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Disables statistics collection
disableStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Disables statistics collection
disableStats() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Disables statistics collection
disableStats() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Disables statistics collection
discard() - Method in class net.sf.ehcache.search.impl.ResultsImpl
Discard this query result.
discard() - Method in class net.sf.ehcache.search.NullResults
Discard this query result.
discard() - Method in interface net.sf.ehcache.search.Results
Discard this query result.
DisconnectedClusterNode - Class in net.sf.ehcache.terracotta
ClusterNode which copies a disconnected ClusterNode without keeping any reference to the original one.
DisconnectedClusterNode(ClusterNode) - Constructor for class net.sf.ehcache.terracotta.DisconnectedClusterNode
Constructor accepting the disconnected node
diskAccessStripes - Variable in class net.sf.ehcache.config.CacheConfiguration
The number of concurrent disk access stripes.
diskAccessStripes(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the number of disk stripes.
DiskBackedMemoryStore - Class in net.sf.ehcache.store
A tiered store using an in-memory cache of elements stored on disk.
diskCapacityChanged(int, int) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates a change in the configurations disk store capacity
diskCapacityChanged(int, int) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates a change in the configurations disk store capacity
diskCapacityChanged(int, int) - Method in class net.sf.ehcache.store.MemoryStore
Indicates a change in the configurations disk store capacity
diskExpiryThreadIntervalSeconds - Variable in class net.sf.ehcache.config.CacheConfiguration
The interval in seconds between runs of the disk expiry thread.
diskExpiryThreadIntervalSeconds(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the interval in seconds between runs of the disk expiry thread.
diskHit() - Method in class net.sf.ehcache.store.disk.Segment
Record a hit in the disk tier
diskPersistent - Variable in class net.sf.ehcache.config.CacheConfiguration
For caches that overflow to disk, whether the disk cache persists between CacheManager instances.
diskPersistent(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets whether the disk store persists between CacheManager instances.
DiskSizeOfEngine - Class in net.sf.ehcache.store.disk
SizeOf engine which calculates exact usage of the disk store.
DiskSizeOfEngine() - Constructor for class net.sf.ehcache.store.disk.DiskSizeOfEngine
 
diskSpoolBufferSizeMB - Variable in class net.sf.ehcache.config.CacheConfiguration
The size of the disk spool used to buffer writes
diskSpoolBufferSizeMB(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the disk spool size, which is used to buffer writes to the DiskStore.
DiskStorageFactory - Class in net.sf.ehcache.store.disk
A mock-up of a on-disk element proxy factory.
DiskStorageFactory(Ehcache, String, RegisteredEventListeners) - Constructor for class net.sf.ehcache.store.disk.DiskStorageFactory
Constructs an disk persistent factory for the given cache and disk path.
DiskStorageFactory.DiskMarker - Class in net.sf.ehcache.store.disk
DiskMarker instances point to the location of their associated serialized Element instance.
DiskStorageFactory.DiskSubstitute - Class in net.sf.ehcache.store.disk
Abstract superclass for all disk substitutes.
DiskStorageFactory.DiskSubstitute() - Constructor for class net.sf.ehcache.store.disk.DiskStorageFactory.DiskSubstitute
Create a disk substitute bound to no factory.
diskStore(DiskStoreConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder to add a disk store to the cache manager, only one disk store can be added.
DiskStore - Class in net.sf.ehcache.store.disk
Implements a persistent-to-disk store.
diskStore - Variable in class net.sf.ehcache.store.LruMemoryStore
The DiskStore associated with this MemoryStore.
DiskStoreBootstrapCacheLoader - Class in net.sf.ehcache.store
 
DiskStoreBootstrapCacheLoader(boolean) - Constructor for class net.sf.ehcache.store.DiskStoreBootstrapCacheLoader
Constructor for loader
DiskStoreBootstrapCacheLoaderFactory - Class in net.sf.ehcache.store
Factory class to create DiskStoreBootstrapCacheLoader instances.
DiskStoreBootstrapCacheLoaderFactory() - Constructor for class net.sf.ehcache.store.DiskStoreBootstrapCacheLoaderFactory
 
DiskStoreConfiguration - Class in net.sf.ehcache.config
A class to represent DiskStore configuration e.g.
DiskStoreConfiguration() - Constructor for class net.sf.ehcache.config.DiskStoreConfiguration
 
DiskStoreConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
Element representing the DiskStoreConfiguration
DiskStoreConfigurationElement(ConfigurationElement, DiskStoreConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.DiskStoreConfigurationElement
Construtor accepting the parent and the DiskStoreConfiguration
diskStorePath - Variable in class net.sf.ehcache.config.CacheConfiguration
The path where the disk store is located
diskStorePath(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the path that will be used for the disk store.
Disposable - Interface in net.sf.ehcache
A Disposable is a resource that needs to release other resources when it is no longer needed.
dispose() - Method in class net.sf.ehcache.Cache
Starts an orderly shutdown of the Cache.
dispose() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Flushes all cache items from memory to auxilliary caches and close the auxilliary caches.
dispose() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Flushes all cache items from memory to auxilliary caches and close the auxilliary caches.
dispose() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Prepares for shutdown.
dispose() - Method in interface net.sf.ehcache.Disposable
Disposes the resource and releases any system resources associated with it.
dispose() - Method in interface net.sf.ehcache.distribution.CacheManagerPeerProvider
Providers may be doing all sorts of exotic things and need to be able to clean up on dispose.
dispose() - Method in class net.sf.ehcache.distribution.MulticastKeepaliveHeartbeatReceiver
Shutdown the heartbeat.
dispose() - Method in class net.sf.ehcache.distribution.MulticastKeepaliveHeartbeatSender
Shutdown this heartbeat sender
dispose() - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
Shutdown the heartbeat
dispose() - Method in class net.sf.ehcache.distribution.RMIAsynchronousCacheReplicator
Give the replicator a chance to flush the replication queue, then cleanup and free resources when no longer needed
dispose() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Stop the listener.
dispose() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
Providers may be doing all sorts of exotic things and need to be able to clean up on dispose.
dispose() - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Give the replicator a chance to cleanup and free resources when no longer needed
dispose() - Method in interface net.sf.ehcache.Ehcache
Flushes all cache items from memory to auxilliary caches and close the auxilliary caches.
dispose() - Method in interface net.sf.ehcache.event.CacheEventListener
Give the listener a chance to cleanup and free resources when no longer needed
dispose() - Method in class net.sf.ehcache.event.CacheEventListenerAdapter
Give the listener a chance to cleanup and free resources when no longer needed
dispose() - Method in interface net.sf.ehcache.event.CacheManagerEventListener
Stop the listener and free any resources.
dispose() - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Tell listeners to dispose themselves.
dispose() - Method in class net.sf.ehcache.event.NonstopCacheEventListener
Give the listener a chance to cleanup and free resources when no longer needed
dispose() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Tell listeners to dispose themselves.
dispose() - Method in class net.sf.ehcache.event.TerracottaCacheEventReplication
Give the listener a chance to cleanup and free resources when no longer needed
dispose() - Method in interface net.sf.ehcache.extension.CacheExtension
Providers may be doing all sorts of exotic things and need to be able to clean up on dispose.
dispose() - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
Dispose of this SampledCacheManager and clean up held resources
dispose() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistrationImpl
Stop the listener and free any resources.
dispose() - Method in interface net.sf.ehcache.loader.CacheLoader
Providers may be doing all sorts of exotic things and need to be able to clean up on dispose.
dispose() - Method in class net.sf.ehcache.management.ManagementService
Stop the listener and free any resources.
dispose() - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Stop the listener and free any resources.
dispose() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called to dispose off the listener
dispose() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Give the listener a chance to cleanup and free resources when no longer needed
dispose() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Give the listener a chance to cleanup and free resources when no longer needed
dispose() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Give the listener a chance to cleanup and free resources when no longer needed
dispose() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called to dispose off the listener
dispose() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Method used to dispose this statistics
dispose() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called to dispose off the listener
dispose() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called to dispose off the listener
dispose() - Method in class net.sf.ehcache.store.disk.DiskStore
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.store.LruMemoryStore
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.store.MemoryStore
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.store.NullStore
Prepares for shutdown.
dispose() - Method in interface net.sf.ehcache.store.Store
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Will shut the keysnapshot thread and other resources down.
dispose() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Prepares for shutdown.
dispose() - Method in class net.sf.ehcache.writer.AbstractCacheWriter
Providers may be doing all sorts of exotic things and need to be able to clean up on dispose.
dispose() - Method in interface net.sf.ehcache.writer.CacheWriter
Providers may be doing all sorts of exotic things and need to be able to clean up on dispose.
dispose() - Method in interface net.sf.ehcache.writer.CacheWriterManager
Cleans up the resources of the cache writer manager.
dispose() - Method in class net.sf.ehcache.writer.writebehind.WriteBehindManager
Cleans up the resources of the cache writer manager.
dispose() - Method in class net.sf.ehcache.writer.writethrough.WriteThroughManager
Cleans up the resources of the cache writer manager.
disposeRMICachePeer(RMICachePeer) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
A template method to dispose an individual RMICachePeer.
doClear() - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Free resources used by this accessor.
doCreateCachePeerListener(String, Integer, Integer, CacheManager, Integer) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListenerFactory
A template method to actually create the factory
doDispose() - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
Dispose callback of subclasses
doDispose() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Dispose callback of subclasses
doDispose() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Dispose callback of subclasses
doDispose() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Dispose callback of subclasses
doDispose() - Method in class net.sf.ehcache.management.sampled.SampledCache
Dispose callback of subclasses
doDispose() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Dispose callback of subclasses
doLoad(Ehcache) - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Bootstraps the cache from a random CachePeer.
doLocalKeySnapshot() - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Calling this method will result in a snapshot being taken or wait for the one in progress to finish
doPut(Element) - Method in class net.sf.ehcache.store.LruMemoryStore
Allow specialised actions over adding the element to the map.
duplicateElementWithNewValue(Element, Object) - Method in class net.sf.ehcache.store.compound.ReadWriteSerializationCopyStrategy
Make a duplicate of an element but using the specified value
dynamicConfig(boolean) - Method in class net.sf.ehcache.config.Configuration
Builder to set the dynamic config capability

E

Ehcache - Interface in net.sf.ehcache
An interface for Ehcache.
EhCache - Class in net.sf.ehcache.hibernate
Deprecated. 
EhCache(Ehcache) - Constructor for class net.sf.ehcache.hibernate.EhCache
Deprecated. Creates a new Hibernate pluggable cache by name.
EHCACHE_HIBERNATE_TYPE - Static variable in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMbeanNames
Type for the ehcache backed hibernate second level cache statistics mbean
EhcacheAccessStrategyFactory - Interface in net.sf.ehcache.hibernate.strategy
Factory to create EntityRegionAccessStrategy
EhcacheAccessStrategyFactoryImpl - Class in net.sf.ehcache.hibernate.strategy
Class implementing EhcacheAccessStrategyFactory
EhcacheAccessStrategyFactoryImpl() - Constructor for class net.sf.ehcache.hibernate.strategy.EhcacheAccessStrategyFactoryImpl
 
EhcacheCollectionRegion - Class in net.sf.ehcache.hibernate.regions
A collection region specific wrapper around an Ehcache instance.
EhcacheCollectionRegion(EhcacheAccessStrategyFactory, Ehcache, Settings, CacheDataDescription, Properties) - Constructor for class net.sf.ehcache.hibernate.regions.EhcacheCollectionRegion
Constructs an EhcacheCollectionRegion around the given underlying cache.
EhcacheDataRegion - Class in net.sf.ehcache.hibernate.regions
An Ehcache specific data region implementation.
EhcacheDecoratorAdapter - Class in net.sf.ehcache.constructs
Adapter class for Ehcache interface decorators.
EhcacheDecoratorAdapter(Ehcache) - Constructor for class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Constructor accepting the cache to be decorated
EhcacheEntityRegion - Class in net.sf.ehcache.hibernate.regions
An entity region specific wrapper around an Ehcache instance.
EhcacheEntityRegion(EhcacheAccessStrategyFactory, Ehcache, Settings, CacheDataDescription, Properties) - Constructor for class net.sf.ehcache.hibernate.regions.EhcacheEntityRegion
Constructs an EhcacheEntityRegion around the given underlying cache.
EhcacheHibernate - Class in net.sf.ehcache.hibernate.management.impl
Implementation of the EhcacheHibernateMBean

EhcacheHibernate(CacheManager) - Constructor for class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Constructor accepting the backing CacheManager
EhcacheHibernateMBean - Interface in net.sf.ehcache.hibernate.management.api
MBean interface for hibernate statistics of session-factories

EhcacheHibernateMbeanNames - Class in net.sf.ehcache.hibernate.management.impl
Utility class used for getting ObjectName's for ehcache hibernate MBeans

EhcacheHibernateMbeanNames() - Constructor for class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMbeanNames
 
EhcacheHibernateMBeanRegistration - Interface in net.sf.ehcache.hibernate.management.impl
Interface for helping registering mbeans for ehcache backed hibernate second-level cache

EhcacheHibernateMBeanRegistrationImpl - Class in net.sf.ehcache.hibernate.management.impl
Implementation of EhcacheHibernateMBeanRegistration.
EhcacheHibernateMBeanRegistrationImpl() - Constructor for class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistrationImpl
 
EhcacheJtaTransactionManagerLookup - Class in net.sf.ehcache.hibernate
Hibernate TransactionManagerLookup which also is a Ehcache transaction manager lookup.
EhcacheJtaTransactionManagerLookup() - Constructor for class net.sf.ehcache.hibernate.EhcacheJtaTransactionManagerLookup
Construct a new transaction manager lookup.
EhcacheNonstrictReadWriteCache - Class in net.sf.ehcache.hibernate.ccs
Deprecated. 
EhcacheNonstrictReadWriteCache() - Constructor for class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated.  
EhCacheProvider - Class in net.sf.ehcache.hibernate
Deprecated. 
EhCacheProvider() - Constructor for class net.sf.ehcache.hibernate.EhCacheProvider
Deprecated.  
EhcacheQueryResultsRegion - Class in net.sf.ehcache.hibernate.regions
A query results region specific wrapper around an Ehcache instance.
EhcacheQueryResultsRegion(EhcacheAccessStrategyFactory, Ehcache, Properties) - Constructor for class net.sf.ehcache.hibernate.regions.EhcacheQueryResultsRegion
Constructs an EhcacheQueryResultsRegion around the given underlying cache.
EhcacheReadOnlyCache - Class in net.sf.ehcache.hibernate.ccs
Deprecated. 
EhcacheReadOnlyCache() - Constructor for class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated.  
EhcacheReadWriteCache - Class in net.sf.ehcache.hibernate.ccs
Deprecated. 
EhcacheReadWriteCache() - Constructor for class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated.  
EhCacheRegionFactory - Class in net.sf.ehcache.hibernate
A non-singleton EhCacheRegionFactory implementation.
EhCacheRegionFactory(Properties) - Constructor for class net.sf.ehcache.hibernate.EhCacheRegionFactory
Creates a non-singleton EhCacheRegionFactory
EhcacheStats - Interface in net.sf.ehcache.hibernate.management.api
Interface for ehcache related statistics of hibernate second level cache

EhcacheStatsImpl - Class in net.sf.ehcache.hibernate.management.impl
Implementation of EhcacheStats

EhcacheStatsImpl(CacheManager) - Constructor for class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Constructor accepting the backing CacheManager
EhcacheTimestampsRegion - Class in net.sf.ehcache.hibernate.regions
A timestamps region specific wrapper around an Ehcache instance.
EhcacheTimestampsRegion(EhcacheAccessStrategyFactory, Ehcache, Properties) - Constructor for class net.sf.ehcache.hibernate.regions.EhcacheTimestampsRegion
Constructs an EhcacheTimestampsRegion around the given underlying cache.
EhcacheTransactionalDataRegion - Class in net.sf.ehcache.hibernate.regions
An Ehcache specific TransactionalDataRegion.
EhcacheXAException - Exception in net.sf.ehcache.transaction.xa
Small extension to the XAException defined in the JTA specification, to that the errorCode is provided when instantiating the Exception thrown
EhcacheXAException(String, int) - Constructor for exception net.sf.ehcache.transaction.xa.EhcacheXAException
Constructor
EhcacheXAException(String, int, Throwable) - Constructor for exception net.sf.ehcache.transaction.xa.EhcacheXAException
Constructor
EhcacheXAResource - Interface in net.sf.ehcache.transaction.xa
EhcacheXAResource represents an Ehcache instance.
EhcacheXAResourceImpl - Class in net.sf.ehcache.transaction.xa
The EhcacheXAResource implementation
EhcacheXAResourceImpl(Ehcache, Store, TransactionManagerLookup, SoftLockFactory, TransactionIDFactory, ReadWriteCopyStrategy<Element>) - Constructor for class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
Constructor
Element - Class in net.sf.ehcache
A Cache Element, consisting of a key, value and attributes.
Element(Serializable, Serializable, long) - Constructor for class net.sf.ehcache.Element
A full constructor.
Element(Object, Object, long) - Constructor for class net.sf.ehcache.Element
A full constructor.
Element(Object, Object, long, long, long, long, long, long) - Constructor for class net.sf.ehcache.Element
Deprecated. The nextToLastAccessTime field is unused since version 1.7, setting it will have no effect. Use #Element(Object, Object, long, long, long, long, long) instead
Element(Object, Object, long, long, long, long, long) - Constructor for class net.sf.ehcache.Element
Constructor.
Element(Object, Object, long, long, long, long, boolean, int, int, long) - Constructor for class net.sf.ehcache.Element
Constructor used by ElementData.
Element(Object, Object, Boolean, Integer, Integer) - Constructor for class net.sf.ehcache.Element
Constructor used by ehcache-server
Element(Serializable, Serializable) - Constructor for class net.sf.ehcache.Element
Constructor.
Element(Object, Object) - Constructor for class net.sf.ehcache.Element
Constructor.
elementCountInMemory - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
in-memory element count
elementCountOnDisk - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
on-disk element count
elementCountTotal - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
total element count
ElementEvictionData - Interface in net.sf.ehcache
Provides pluggable storage and configuration of TTI eviction data.
elementSet() - Method in class net.sf.ehcache.store.MemoryStore
Get a collection of the elements in this store
ElementSubstituteFilter - Interface in net.sf.ehcache.store.disk
Filter on Elements or ElementSubstitutes.
ElementValueComparator - Interface in net.sf.ehcache.store
Used to compare two element values.
ElementValueComparatorConfiguration - Class in net.sf.ehcache.config
 
ElementValueComparatorConfiguration() - Constructor for class net.sf.ehcache.config.ElementValueComparatorConfiguration
 
ElementValueComparatorConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the ElementValueComparatorConfiguration
ElementValueComparatorConfigurationElement(NodeElement, ElementValueComparatorConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.ElementValueComparatorConfigurationElement
Constructor accepting the parent and the ElementValueComparatorConfiguration
emitter - Variable in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
emitter
ENABLE_SHUTDOWN_HOOK_PROPERTY - Static variable in class net.sf.ehcache.CacheManager
System property to enable creation of a shutdown hook for CacheManager.
enableAllOutputBehaviors() - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Enables all output behaviors
enabled(boolean) - Method in class net.sf.ehcache.config.NonstopConfiguration
Set the value of nonstop
enableHibernateStatistics(SessionFactory) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Enable hibernate statistics with the input session factory
enableHibernateStatisticsSupport(SessionFactory) - Method in interface net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistration
Enable hibernate statistics in the mbean.
enableHibernateStatisticsSupport(SessionFactory) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistrationImpl
Enable hibernate statistics in the mbean.
enableOutputBehavior(XMLGeneratorVisitor.OutputBehavior) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Enables one particular XMLGeneratorVisitor.OutputBehavior
enableSampledStatistics() - Method in class net.sf.ehcache.management.sampled.SampledCache
Enables statistics collection.
enableSampledStatistics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Enables statistics collection.
enableSampledStatistics(FailSafeTimer) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Enable sampled statistics collection
enableStatistics() - Method in class net.sf.ehcache.management.sampled.SampledCache
Enables statistics collection
enableStatistics() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Enable statistics for each cache contained by cacheManager
enableStatistics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Enable statistics for each cache contained by cacheManager
enableStatistics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Enables statistics collection
enableStats() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Enables statistics collection
enableStats() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Enables statistics collection
enableStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Enables statistics collection
enableStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Enables statistics collection
enableStats() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Enables statistics collection
enableStats() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Enables statistics collection
end() - Method in interface net.sf.ehcache.search.Query
Optional method for terminating query creation.
end() - Method in class net.sf.ehcache.store.disk.ods.Region
Returns the end of this range (inclusive).
end(Xid, int) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
endAttributes(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Finish visiting attributes of the element.
endAttributes(NodeElement) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Finish visiting attributes of the element.
endChildren(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Finish visiting children of the element.
endChildren(NodeElement) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Finish visiting children of the element.
endElement(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Finish visiting the element.
endElement(NodeElement) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Finish visiting the element.
EntityStats - Class in net.sf.ehcache.hibernate.management.impl
When we only support Java 6, all of this OpenMBean scaffolding can be removed in favor or MXBeans.
EntityStats(String) - Constructor for class net.sf.ehcache.hibernate.management.impl.EntityStats
 
EntityStats(String, EntityStatistics) - Constructor for class net.sf.ehcache.hibernate.management.impl.EntityStats
 
EntityStats(CompositeData) - Constructor for class net.sf.ehcache.hibernate.management.impl.EntityStats
 
entrySet() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
eq(T) - Method in class net.sf.ehcache.search.Attribute
Create a criteria where this attribute is equal to the given value
equals(Object) - Method in class net.sf.ehcache.Cache
An equals method which follows the contract of Object.equals(Object)

An Cache is equal to another one if it implements Ehcache and has the same GUID.

equals(Object) - Method in class net.sf.ehcache.config.CacheWriterConfiguration.CacheWriterFactoryConfiguration
Overrided equals
equals(Object) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Overrided equals()
equals(Object) - Method in class net.sf.ehcache.config.CopyStrategyConfiguration
equals(Object) - Method in class net.sf.ehcache.config.ElementValueComparatorConfiguration
equals(Object) - Method in class net.sf.ehcache.config.FactoryConfiguration
Overrided equals
equals(Object) - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
equals(Object) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
equals(Object) - Method in class net.sf.ehcache.config.NonstopConfiguration
 
equals(Object) - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
 
equals(Object) - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
 
equals(Object) - Method in class net.sf.ehcache.distribution.ConfigurableRMIClientSocketFactory
The standard hashCode method which is necessary for SocketFactory classes.
equals(Object) - Method in class net.sf.ehcache.Element
Equals comparison with another element, based on the key.
equals(Object) - Method in class net.sf.ehcache.search.Attribute
equals(Object) - Method in class net.sf.ehcache.Status
Indicates whether some other object is "equal to" this one.
equals(Status) - Method in class net.sf.ehcache.Status
Equality checker when the comparison object is of the same type.
equals(Element, Element) - Method in class net.sf.ehcache.store.DefaultElementValueComparator
Compare if the two element values are equal
equals(Element, Element) - Method in interface net.sf.ehcache.store.ElementValueComparator
Compare if the two element values are equal
equals(Object) - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
equals(Object) - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
equals(Object) - Method in class net.sf.ehcache.transaction.TransactionIDImpl
equals(Object) - Method in class net.sf.ehcache.transaction.xa.SerializableXid
equals(Object) - Method in class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
EqualTo - Class in net.sf.ehcache.search.expression
A comparison operator meaning Java "equals to" condition
EqualTo(String, Object) - Constructor for class net.sf.ehcache.search.expression.EqualTo
Constructor
eternal - Variable in class net.sf.ehcache.config.CacheConfiguration
Sets whether elements are eternal.
eternal(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets whether elements are eternal.
event() - Method in class net.sf.ehcache.util.ratestatistics.AtomicRateStatistic
Fired to record the occurrence of a monitored event.
event() - Method in interface net.sf.ehcache.util.ratestatistics.RateStatistic
Fired to record the occurrence of a monitored event.
event() - Method in class net.sf.ehcache.util.ratestatistics.UnlockedRateStatistic
Fired to record the occurrence of a monitored event.
EventMessage - Class in net.sf.ehcache.distribution
An Event Message, in respect of a particular cache.
EventMessage(Ehcache, Serializable) - Constructor for class net.sf.ehcache.distribution.EventMessage
Full constructor.
evict(Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. Removes the stale item.
evict(Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. A No-Op, since we are an asynchronous cache concurrency strategy.
evict(Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. A No-Op, since we are an asynchronous cache concurrency strategy.
evict(Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
evict(Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
evict(T, int, long) - Method in class net.sf.ehcache.pool.impl.AbstractBalancedAccessEvictor
Evict the specified number of bytes or the hinted number of elements from the specified store
evict(int, long, PoolableStore) - Method in class net.sf.ehcache.pool.impl.AbstractFromLargestCachePoolEvictor
Evict from a store for a chosen resource
evict(PoolableStore, int, long) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnDiskPoolEvictor
Evict the specified number of bytes or the hinted number of elements from the specified store
evict(PoolableStore, int, long) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnHeapPoolEvictor
Evict the specified number of bytes or the hinted number of elements from the specified store
evict(int, long, PoolableStore) - Method in class net.sf.ehcache.pool.impl.FromLargestCacheOnDiskPoolEvictor
Evict from a store for a chosen resource
evict(int, long, PoolableStore) - Method in class net.sf.ehcache.pool.impl.FromLargestCacheOnHeapPoolEvictor
Evict from a store for a chosen resource
evict() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
evict(Object, DiskStorageFactory.DiskSubstitute) - Method in class net.sf.ehcache.store.disk.DiskStore
Remove the matching mapping.
evict(Element) - Method in class net.sf.ehcache.store.LruMemoryStore
Evict the Element.
evict(Element) - Method in class net.sf.ehcache.store.MemoryStore
Evicts the element from the store
evict(Element) - Method in class net.sf.ehcache.store.NotifyingMemoryStore
Evicts the element from the store
evictAll() - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
evictAll() - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
evictElement(Object, DiskStorageFactory.DiskSubstitute) - Method in class net.sf.ehcache.store.disk.DiskStore
Remove the matching mapping.
evictExpiredElements() - Method in class net.sf.ehcache.Cache
Causes all elements stored in the Cache to be synchronously checked for expiry, and if expired, evicted.
evictExpiredElements() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Causes all elements stored in the Cache to be synchronously checked for expiry, and if expired, evicted.
evictExpiredElements() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Causes all elements stored in the Cache to be synchronously checked for expiry, and if expired, evicted.
evictExpiredElements() - Method in interface net.sf.ehcache.Ehcache
Causes all elements stored in the Cache to be synchronously checked for expiry, and if expired, evicted.
evictFromOnDisk(int, long) - Method in interface net.sf.ehcache.pool.PoolableStore
Perform eviction to release on-disk resources
evictFromOnDisk(int, long) - Method in class net.sf.ehcache.store.disk.DiskStore
Perform eviction to release on-disk resources
evictFromOnDisk(int, long) - Method in class net.sf.ehcache.store.MemoryStore
Perform eviction to release on-disk resources
evictFromOnHeap(int, long) - Method in interface net.sf.ehcache.pool.PoolableStore
Perform eviction to release on-heap resources
evictFromOnHeap(int, long) - Method in class net.sf.ehcache.store.disk.DiskStore
Perform eviction to release on-heap resources
evictFromOnHeap(int, long) - Method in class net.sf.ehcache.store.MemoryStore
Perform eviction to release on-heap resources
EXCEPTION_TYPE_NAME - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Type name for TimeoutBehaviorConfiguration.TimeoutBehaviorType.EXCEPTION
ExceptionHandlingDynamicCacheProxy - Class in net.sf.ehcache.exceptionhandler
A dynamic proxy which provides CacheException handling.
ExceptionHandlingDynamicCacheProxy(Ehcache) - Constructor for class net.sf.ehcache.exceptionhandler.ExceptionHandlingDynamicCacheProxy
Constructor: Use with something like:
ExceptionOnTimeoutStore - Class in net.sf.ehcache.constructs.nonstop.store
Implementation of NonstopStore that throws NonStopCacheException for all operations.
execute(Callable<V>, long) - Method in interface net.sf.ehcache.constructs.nonstop.NonstopExecutorService
Execute a Callable task with timeout.
execute(Callable<V>, long) - Method in class net.sf.ehcache.constructs.nonstop.NonstopExecutorServiceImpl
Execute a Callable task with timeout.
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.AlwaysMatch
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.And
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.ComparableValue
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in interface net.sf.ehcache.search.expression.Criteria
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.EqualTo
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.ILike
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.InCollection
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.Not
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.NotEqualTo
Test this criteria against a cache element
execute(Element, Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.search.expression.Or
Test this criteria against a cache element
execute() - Method in interface net.sf.ehcache.search.Query
Execute this query.
execute(Callable) - Method in class net.sf.ehcache.transaction.xa.processor.XAThreadPool.MultiRunner
Execute a Callable on the wrapped thread and return its result
executeClusterOperation(ClusterOperation<V>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Execute the ClusterOperation within this NonstopStore context.
executeClusterOperation(ClusterOperation<V>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Execute the ClusterOperation within this NonstopStore context.
executeClusterOperation(ClusterOperation<V>) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Execute the ClusterOperation within this NonstopStore context.
executeClusterOperation(ClusterOperation<V>) - Method in interface net.sf.ehcache.constructs.nonstop.store.NonstopStore
Execute the ClusterOperation within this NonstopStore context.
executeClusterOperation(ClusterOperation<V>) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Execute the ClusterOperation within this NonstopStore context.
executeClusterOperation(ClusterOperation<V>) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Execute the ClusterOperation within this NonstopStore context.
executeClusterOperationNoTimeout(ClusterOperation<V>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Executes the ClusterOperation parameter, but without any timeout.
executeComparable(Comparable) - Method in class net.sf.ehcache.search.expression.Between
Execute this criteria for the given Comparable attribute value
executeComparable(Comparable) - Method in class net.sf.ehcache.search.expression.ComparableValue
Execute this criteria for the given Comparable attribute value
executeComparable(Comparable) - Method in class net.sf.ehcache.search.expression.GreaterThan
Execute this criteria for the given Comparable attribute value
executeComparable(Comparable) - Method in class net.sf.ehcache.search.expression.GreaterThanOrEqual
Execute this criteria for the given Comparable attribute value
executeComparable(Comparable) - Method in class net.sf.ehcache.search.expression.LessThan
Execute this criteria for the given Comparable attribute value
executeComparable(Comparable) - Method in class net.sf.ehcache.search.expression.LessThanOrEqual
Execute this criteria for the given Comparable attribute value
executeComparableString(Comparable) - Method in class net.sf.ehcache.search.expression.Between
Execute this criteria for the given Comparable strin type attribute value
executeComparableString(Comparable) - Method in class net.sf.ehcache.search.expression.ComparableValue
Execute this criteria for the given Comparable strin type attribute value
executeComparableString(Comparable) - Method in class net.sf.ehcache.search.expression.GreaterThan
Execute this criteria for the given Comparable strin type attribute value
executeComparableString(Comparable) - Method in class net.sf.ehcache.search.expression.GreaterThanOrEqual
Execute this criteria for the given Comparable strin type attribute value
executeComparableString(Comparable) - Method in class net.sf.ehcache.search.expression.LessThan
Execute this criteria for the given Comparable strin type attribute value
executeComparableString(Comparable) - Method in class net.sf.ehcache.search.expression.LessThanOrEqual
Execute this criteria for the given Comparable strin type attribute value
executeQuery(StoreQuery) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Execute the given query on this store
executeQuery(StoreQuery) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Execute the given query on this store
executeQuery(StoreQuery) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Execute the given query on this store
executeQuery(StoreQuery) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Execute the given query on this store
executeQuery(StoreQuery) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Execute the given query on this store
executeQuery(StoreQuery) - Method in class net.sf.ehcache.store.AbstractStore
Execute the given query on this store
executeQuery(StoreQuery) - Method in class net.sf.ehcache.store.MemoryOnlyStore
Execute the given query on this store
executeQuery(StoreQuery) - Method in interface net.sf.ehcache.store.Store
Execute the given query on this store
executeQuery(StoreQuery) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Execute the given query on this store
executeWithExecutor(Callable<V>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Execute call within NonStop executor
executeWithExecutor(Callable<V>, long) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Execute call within NonStop executor
executionAvgTime - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
executionAvgTime
executionCount - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
executionCount
executionMaxTime - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
executionMaxTime
executionMinTime - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
executionMinTime
executionRowCount - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
executionRowCount
ExecutorServiceStore - Class in net.sf.ehcache.constructs.nonstop.store
This implementation executes all operations using a NonstopExecutorService.
ExecutorServiceStore(NonstopActiveDelegateHolder, NonstopConfiguration, NonstopTimeoutBehaviorStoreResolver, CacheCluster, ExplicitLockingContextThreadLocal) - Constructor for class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Constructor accepting the NonstopActiveDelegateHolder, NonstopConfiguration and NonstopTimeoutBehaviorStoreResolver
expireElement(Object) - Method in class net.sf.ehcache.store.MemoryStore
Evicts the element for the given key, if it exists and is expired
expireElements() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Expire all elements.
expireElements() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Expire all elements.
expireElements() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Expire all elements.
expireElements() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Expire all elements.
expireElements() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Expire all elements.
expireElements() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Remove elements created by this factory if they have expired.
expireElements() - Method in class net.sf.ehcache.store.disk.DiskStore
Expire all elements.
expireElements() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Expire all elements.
expireElements() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Expire all elements.
expireElements() - Method in class net.sf.ehcache.store.LruMemoryStore
Expire all elsments.
expireElements() - Method in class net.sf.ehcache.store.MemoryStore
Expire all elements.
expireElements() - Method in class net.sf.ehcache.store.NotifyingMemoryStore
Expire all elements.
expireElements() - Method in class net.sf.ehcache.store.NullStore
Expire all elements.
expireElements() - Method in interface net.sf.ehcache.store.Store
Expire all elements.
expireElements() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Expire all elements.
ExplicitLockingContextThreadLocal - Class in net.sf.ehcache.constructs.nonstop.concurrency
A class that maintains a thread local to keep track of any explicit locks acquired by the app thread
ExplicitLockingContextThreadLocal() - Constructor for class net.sf.ehcache.constructs.nonstop.concurrency.ExplicitLockingContextThreadLocal
Public constructor
expression(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the attribute expression
extractAndLogProperty(String, Properties) - Static method in class net.sf.ehcache.util.PropertyUtil
 
extractAndLogProperty(String, Map) - Static method in class net.sf.ehcache.util.PropertyUtil
 
extractBoolean(Properties, String, boolean) - Method in class net.sf.ehcache.bootstrap.BootstrapCacheLoaderFactory
Will retrieve the boolean value from the properties, defaulting if property isn't present
extractBootstrapAsynchronously(Properties) - Method in class net.sf.ehcache.bootstrap.BootstrapCacheLoaderFactory
Extracts the value of bootstrapAsynchronously from the properties
extractLong(Properties, String, long) - Method in class net.sf.ehcache.bootstrap.BootstrapCacheLoaderFactory
Will retrieve the boolean value from the properties, defaulting if property isn't present
extractMaximumBatchSize(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Extracts the value of maximumBatchSize.
extractMaximumChunkSizeBytes(Properties) - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoaderFactory
 
extractReplicateAsynchronously(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Extracts the value of replicateAsynchronously from the properties
extractReplicatePuts(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Extracts the value of replicatePuts from the properties
extractReplicatePutsViaCopy(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Extracts the value of replicatePutsViaCopy from the properties
extractReplicateRemovals(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Extracts the value of replicateRemovals from the properties
extractReplicateUpdates(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Extracts the value of replicateUpdates from the properties
extractReplicateUpdatesViaCopy(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Extracts the value of replicateUpdatesViaCopy from the properties
extractReplicationIntervalMilis(Properties) - Method in class net.sf.ehcache.distribution.RMICacheReplicatorFactory
Extracts the value of asynchronousReplicationIntervalMillis.
extractTcconfig(String) - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Tell the BeanHandler to extract the entire subtree xml as text at element .

F

factory - Variable in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
A factory for creating entries, given a key
FACTORY - Static variable in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
The NonstopTimeoutBehaviorFactory to create ExceptionOnTimeoutStore stores
FACTORY - Static variable in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
The NonstopTimeoutBehaviorFactory to create LocalReadsOnTimeoutStore stores
FACTORY - Static variable in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
The NonstopTimeoutBehaviorFactory to create NoOpOnTimeoutStore stores
FactoryConfiguration<T extends FactoryConfiguration> - Class in net.sf.ehcache.config
A class to represent the CacheManagerEventListener configuration.
FactoryConfiguration() - Constructor for class net.sf.ehcache.config.FactoryConfiguration
 
FactoryConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the FactoryConfiguration
FactoryConfigurationElement(NodeElement, String, FactoryConfiguration<? extends FactoryConfiguration>) - Constructor for class net.sf.ehcache.config.generator.model.elements.FactoryConfigurationElement
Constructor accepting the parent, the name and the FactoryConfiguration
FailSafeTimer - Class in net.sf.ehcache.util
A fail-safe timer in the sense that if the runtime environment restricts creating new threads, it doesn't blow up with an exception.
FailSafeTimer(String) - Constructor for class net.sf.ehcache.util.FailSafeTimer
Constructor accepting a name for the timer.
fault(Object, DiskStorageFactory.Placeholder, DiskStorageFactory.DiskMarker) - Method in class net.sf.ehcache.store.disk.DiskStore
Atomically switch (CAS) the expect representation of this element for the fault representation.
fetchAndPutElements(Ehcache, List, CachePeer) - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Fetches a chunk of elements from a remote cache peer
fetchCount - Variable in class net.sf.ehcache.hibernate.management.impl.CollectionStats
fetchCount
fetchCount - Variable in class net.sf.ehcache.hibernate.management.impl.EntityStats
fetchCount
FIFO - Static variable in class net.sf.ehcache.store.MemoryStoreEvictionPolicy
FIFO - first in first out, the oldest element by creation time.
FifoPolicy - Class in net.sf.ehcache.store
Contains common LFU policy code for use between the LfuMemoryStore and the DiskStore, which also uses an LfuPolicy for evictions.
FifoPolicy() - Constructor for class net.sf.ehcache.store.FifoPolicy
 
FileAllocationTree - Class in net.sf.ehcache.store.disk.ods
File allocation tree allows C-like alloc/free operations on a random access file.
FileAllocationTree(long, RandomAccessFile) - Constructor for class net.sf.ehcache.store.disk.ods.FileAllocationTree
Create a file allocation tree for the given file, capping it's size at maxSize.
fill(Element) - Method in class net.sf.ehcache.store.disk.DiskStore
Add this element to the cache if the key is already present or the add can succeed without resorting to eviction.
fill(Element) - Method in class net.sf.ehcache.store.MemoryStore
Add this element to the cache if the key is already present or the add can succeed without resorting to eviction.
fill(Element) - Method in class net.sf.ehcache.store.NullStore
Add this element to the cache if the key is already present or the add can succeed without resorting to eviction.
fill(Element) - Method in interface net.sf.ehcache.store.TierableStore
Add this element to the cache if the key is already present or the add can succeed without resorting to eviction.
filter(List, OperationConverter<KeyBasedOperation>) - Method in class net.sf.ehcache.writer.writebehind.CoalesceKeysFilter
Filter the operations of a write behind queue.
filter(List, OperationConverter<T>) - Method in interface net.sf.ehcache.writer.writebehind.OperationsFilter
Filter the operations of a write behind queue.
filterClass(Class<?>) - Method in class net.sf.ehcache.pool.sizeof.filter.AnnotationSizeOfFilter
Checks whether the type needs to be filtered
filterClass(Class<?>) - Method in class net.sf.ehcache.pool.sizeof.filter.CombinationSizeOfFilter
Checks whether the type needs to be filtered
filterClass(Class<?>) - Method in class net.sf.ehcache.pool.sizeof.filter.PassThroughFilter
Checks whether the type needs to be filtered
filterClass(Class<?>) - Method in class net.sf.ehcache.pool.sizeof.filter.ResourceSizeOfFilter
Checks whether the type needs to be filtered
filterClass(Class<?>) - Method in interface net.sf.ehcache.pool.sizeof.filter.SizeOfFilter
Checks whether the type needs to be filtered
filterFields(Class<?>, Collection<Field>) - Method in class net.sf.ehcache.pool.sizeof.filter.AnnotationSizeOfFilter
Returns the fields to walk and measure for a type
filterFields(Class<?>, Collection<Field>) - Method in class net.sf.ehcache.pool.sizeof.filter.CombinationSizeOfFilter
Returns the fields to walk and measure for a type
filterFields(Class<?>, Collection<Field>) - Method in class net.sf.ehcache.pool.sizeof.filter.PassThroughFilter
Returns the fields to walk and measure for a type
filterFields(Class<?>, Collection<Field>) - Method in class net.sf.ehcache.pool.sizeof.filter.ResourceSizeOfFilter
Returns the fields to walk and measure for a type
filterFields(Class<?>, Collection<Field>) - Method in interface net.sf.ehcache.pool.sizeof.filter.SizeOfFilter
Returns the fields to walk and measure for a type
find(Object) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
Find the node within this tree equal to the probe node.
FindBugsSuppressWarnings - Annotation Type in net.sf.ehcache.util
Annotation used to suppress FindBugs warnings in Ehcache core code.
firePropertyChange(String, Object, Object) - Method in class net.sf.ehcache.Cache
 
first() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
FIVE_KB - Static variable in class net.sf.ehcache.distribution.RMIBootstrapCacheLoaderFactory
The lowest reasonable chunk size in bytes
flush() - Method in class net.sf.ehcache.Cache
Flushes all cache items from memory to the disk store, and from the DiskStore to disk.
flush() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Flushes all cache items from memory to the disk store, and from the DiskStore to disk.
flush() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Flushes all cache items from memory to the disk store, and from the DiskStore to disk.
flush() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Flush elements to persistent store.
flush() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Flush elements to persistent store.
flush() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Flush elements to persistent store.
flush() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Flush elements to persistent store.
flush() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Flush elements to persistent store.
flush() - Method in interface net.sf.ehcache.Ehcache
Flushes all cache items from memory to the disk store, and from the DiskStore to disk.
flush() - Method in class net.sf.ehcache.management.Cache
Flushes all cache items from memory to the disk store, and from the DiskStore to disk.
flush() - Method in interface net.sf.ehcache.management.CacheMBean
Flushes all cache items from memory to the disk store, and from the DiskStore to disk.
flush() - Method in class net.sf.ehcache.management.sampled.SampledCache
Flushes all cache items from memory to the disk store, and from the DiskStore to disk.
flush() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Flushes all cache items from memory to the disk store, and from the DiskStore to disk.
flush() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Schedule a flush (index write) for this factory.
flush() - Method in class net.sf.ehcache.store.disk.DiskStore
Flush elements to persistent store.
flush() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Flush elements to persistent store.
flush() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Flush elements to persistent store.
flush() - Method in class net.sf.ehcache.store.LruMemoryStore
Flush to disk only if the cache is diskPersistent.
flush() - Method in class net.sf.ehcache.store.MemoryStore
Flush to disk only if the cache is diskPersistent.
flush() - Method in class net.sf.ehcache.store.NullStore
Flush elements to persistent store.
flush() - Method in interface net.sf.ehcache.store.Store
Flush elements to persistent store.
flush() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Flush elements to persistent store.
flushRegionCache(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Flushes the cache for the input region
flushRegionCache(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Flushes the cache for the input region
flushRegionCache(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Flushes the cache for the input region
flushRegionCaches() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Flushes all the caches for all the regions
flushRegionCaches() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Flushes all the caches for all the regions
flushRegionCaches() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Flushes all the caches for all the regions
forget(Xid) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
forgetInternal(Xid) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
The forget implementation
forUnit(char) - Static method in enum net.sf.ehcache.config.MemoryUnit
Returns the MemoryUnit instance based on provided char
free(Lock, DiskStorageFactory.DiskSubstitute) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Free any manually managed resources used by this DiskStorageFactory.DiskSubstitute.
free(Lock, DiskStorageFactory.DiskSubstitute, boolean) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Free any manually managed resources used by this DiskStorageFactory.DiskSubstitute.
free(DiskStorageFactory.DiskMarker) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Free the given marker to be used by a subsequent write.
free(Region) - Method in class net.sf.ehcache.store.disk.ods.FileAllocationTree
Mark this region as free.
freeSpace(Collection<T>, long) - Method in class net.sf.ehcache.pool.impl.AbstractBalancedAccessEvictor
Free at least N bytes from a collection of resources
freeSpace(Collection<PoolableStore>, long) - Method in class net.sf.ehcache.pool.impl.AbstractFromLargestCachePoolEvictor
Free at least N bytes from a collection of resources
freeSpace(Collection<T>, long) - Method in interface net.sf.ehcache.pool.PoolEvictor
Free at least N bytes from a collection of resources
freeze() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Freeze the soft lock.
freeze() - Method in interface net.sf.ehcache.transaction.SoftLock
Freeze the soft lock.
freezeConfig() - Method in class net.sf.ehcache.config.NonstopConfiguration
Freeze the config.
freezeConfig() - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Freezes the config
freezeConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Freeze this configuration.
freezeConfiguration() - Method in class net.sf.ehcache.config.Searchable
Freeze this configuration.
FromLargestCacheOnDiskPoolEvictor - Class in net.sf.ehcache.pool.impl
Pool evictor which always evicts from the store consuming the most disk resources.
FromLargestCacheOnDiskPoolEvictor() - Constructor for class net.sf.ehcache.pool.impl.FromLargestCacheOnDiskPoolEvictor
 
FromLargestCacheOnHeapPoolEvictor - Class in net.sf.ehcache.pool.impl
Pool evictor which always evicts from the store consuming the most heap resources.
FromLargestCacheOnHeapPoolEvictor() - Constructor for class net.sf.ehcache.pool.impl.FromLargestCacheOnHeapPoolEvictor
 
fromString(String) - Static method in class net.sf.ehcache.store.MemoryStoreEvictionPolicy
Converts a string representation of the policy into a policy.
fromTabularData(TabularData) - Static method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
fromTabularData(TabularData) - Static method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
fromTabularData
fromTabularData(TabularData) - Static method in class net.sf.ehcache.hibernate.management.impl.EntityStats
fromTabularData
fromTabularData(TabularData) - Static method in class net.sf.ehcache.hibernate.management.impl.QueryStats
fromTabularData
FrontEndCacheTier<T extends TierableStore,U extends TierableStore> - Class in net.sf.ehcache.store
Abstract class for stores which combine two other stores, one caching the other (aka authority)'s elements.
FrontEndCacheTier(T, U, ReadWriteCopyStrategy<Element>, boolean, boolean) - Constructor for class net.sf.ehcache.store.FrontEndCacheTier
Constructor for FrontEndCacheTier
fullyQualifiedClassPath - Variable in class net.sf.ehcache.config.FactoryConfiguration
class name.

G

ge(T) - Method in class net.sf.ehcache.search.Attribute
Create a criteria where this attribute is greater than or equal to the given value
generate(Configuration, CacheConfiguration, Map<String, CacheConfiguration>) - Method in class net.sf.ehcache.config.generator.ConfigurationGenerator
Deprecated. use appropriate methods in ConfigurationUtil instead
generate(Configuration, CacheConfiguration) - Method in class net.sf.ehcache.config.generator.ConfigurationGenerator
Deprecated. use appropriate methods in ConfigurationUtil instead
generateActiveConfigDeclaration() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the currently active cache configuration
generateActiveConfigDeclaration(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the currently active cache configuration for the supplied region
generateActiveConfigDeclaration() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the currently active cache configuration
generateActiveConfigDeclaration(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the currently active cache configuration for the supplied region
generateActiveConfigDeclaration() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the currently active cache configuration
generateActiveConfigDeclaration(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the currently active cache configuration for the supplied region
generateActiveConfigDeclaration() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
generateActiveConfigDeclaration
generateActiveConfigDeclaration(String) - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
generateActiveConfigDeclaration
generateActiveConfigDeclaration() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
generateActiveConfigDeclaration
generateActiveConfigDeclaration(String) - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
generateActiveConfigDeclaration
generateCacheConfigurationText(Configuration, CacheConfiguration) - Static method in class net.sf.ehcache.config.generator.ConfigurationUtil
Generates configuration text for a CacheConfiguration
generateCacheManagerConfigurationText(CacheManager) - Static method in class net.sf.ehcache.config.generator.ConfigurationUtil
Generates Configuration text from a CacheManager
generateCacheManagerConfigurationText(Configuration) - Static method in class net.sf.ehcache.config.generator.ConfigurationUtil
Generates Configuration text from a Configuration
generateDefaultDecoratedCacheName(Ehcache, String) - Static method in class net.sf.ehcache.constructs.CacheDecoratorFactory
Utility method to generate name of decorated cache to be created using factory specified in defaultCache.
generateRandomSample(int) - Static method in class net.sf.ehcache.store.AbstractPolicy
Generates a random sample from a population
generateUniqueDirectory() - Static method in class net.sf.ehcache.store.disk.DiskStore
Generates a unique directory name for use in automatically creating a diskStorePath where there is a conflict.
get(Serializable) - Method in class net.sf.ehcache.Cache
Gets an element from the cache.
get(Object) - Method in class net.sf.ehcache.Cache
Gets an element from the cache.
get(Object) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Looks up an entry.
get(Serializable) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Gets an element from the cache.
get(Object) - Method in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Looks up an entry.
get(Object) - Method in class net.sf.ehcache.constructs.blocking.UpdatingSelfPopulatingCache
Looks up an object.
get(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets an element from the cache.
get(Serializable) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets an element from the cache.
get(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets an element from the cache.
get(Serializable) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets an element from the cache.
get(int) - Method in class net.sf.ehcache.constructs.nonstop.concurrency.NonStopCacheKeySet
get(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Gets an item from the cache.
get(Serializable) - Method in interface net.sf.ehcache.Ehcache
Gets an element from the cache.
get(Object) - Method in interface net.sf.ehcache.Ehcache
Gets an element from the cache.
get(Object, long) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. 
get(Object, long) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. 
get(Object, long) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. 
get(Object) - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Gets a value of an element which matches the given key.
get(Object, long) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
get(Object, long) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
get(Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Get the value mapped to this key, or null if no value is mapped to this key.
get(Object, long) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheCollectionRegionAccessStrategy
get(Object, long) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
get(Object, long) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheCollectionRegionAccessStrategy
get(Object, long) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
get(Object, long) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheCollectionRegionAccessStrategy
get(Object, long) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
get(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.store.LruMemoryStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.store.MemoryStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.store.NullStore
Gets an item from the cache.
get(Object) - Method in interface net.sf.ehcache.store.Store
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Gets an item from the cache.
get(Object) - Method in class net.sf.ehcache.transaction.xa.XATransactionContext
Filter to get operations on underlying Store.
get(Object) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Gets an item from the cache.
get() - Method in class net.sf.ehcache.util.lang.VicariousThreadLocal
 
get(int) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
get(K) - Method in class net.sf.ehcache.util.WeakIdentityConcurrentMap
 
getActiveConfigurationText() - Method in class net.sf.ehcache.CacheManager
Returns the active configuration text for this CacheManager
getActiveConfigurationText(String) - Method in class net.sf.ehcache.CacheManager
Returns the active configuration text for the input cacheName
getActualFactory() - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Returns the actual underlying factory
getAddedKeys() - Method in class net.sf.ehcache.transaction.xa.XATransactionContext
Queries the local tx context, whether the key is pending removal
getAgentSizeOfAdjustment() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
The size of the jvm-specific agent result adjustment in bytes.
getAggregatorInstances() - Method in interface net.sf.ehcache.store.StoreQuery
Get the requested aggregators
getAggregatorResults() - Method in class net.sf.ehcache.search.impl.BaseResult
Retrieve the aggregator value(s)
getAggregatorResults() - Method in interface net.sf.ehcache.search.Result
Retrieve the aggregator value(s)
getAll(Collection<?>) - Method in class net.sf.ehcache.Cache
Gets all the elements from the cache for the keys provided.
getAll(Collection) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets all the elements from the cache for the keys provided.
getAll(Collection<?>) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets all the elements from the cache for the keys provided.
getAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Retries the elements associated with a set of keys and update the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Retries the elements associated with a set of keys and update the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Retries the elements associated with a set of keys and update the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Retries the elements associated with a set of keys and update the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Retries the elements associated with a set of keys and update the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAll(Collection<?>) - Method in interface net.sf.ehcache.Ehcache
Gets all the elements from the cache for the keys provided.
getAll(Collection<?>) - Method in class net.sf.ehcache.store.AbstractStore
Retries the elements associated with a set of keys and update the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAll(Collection<?>) - Method in interface net.sf.ehcache.store.Store
Retries the elements associated with a set of keys and update the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAllFactoryElements(NodeElement, String, Collection<? extends FactoryConfiguration>) - Static method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Helper method that creates FactoryConfigurationElement's from a collection of FactoryConfiguration's
getAllLocks() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Returns all ReadWriteLockSyncs guarding this store.
getAllQuiet(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Retries the elements associated with a set of keys without updating the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAllQuiet(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Retries the elements associated with a set of keys without updating the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAllQuiet(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Retries the elements associated with a set of keys without updating the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAllQuiet(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Retries the elements associated with a set of keys without updating the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAllQuiet(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Retries the elements associated with a set of keys without updating the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAllQuiet(Collection<?>) - Method in class net.sf.ehcache.store.AbstractStore
Retries the elements associated with a set of keys without updating the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAllQuiet(Collection<?>) - Method in interface net.sf.ehcache.store.Store
Retries the elements associated with a set of keys without updating the statistics Keys which are not present in the cache will have null values associated with them in the returned map
getAllSampleValues() - Method in interface net.sf.ehcache.util.counter.sampled.SampledCounter
Returns all samples in history
getAllSampleValues() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
Returns all samples in history
getAllSyncs() - Method in interface net.sf.ehcache.concurrent.StripedReadWriteLock
Returns all Syncs
getAllSyncs() - Method in class net.sf.ehcache.concurrent.StripedReadWriteLockSync
Returns all internal syncs
getAllWithLoader(Collection, Object) - Method in class net.sf.ehcache.Cache
The getAll method will return, from the cache, a Map of the objects associated with the Collection of keys in argument "keys".
getAllWithLoader(Collection, Object) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
This method is not appropriate to use with BlockingCache.
getAllWithLoader(Collection, Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
The getAll method will return, from the cache, a Map of the objects associated with the Collection of keys in argument "keys".
getAllWithLoader(Collection, Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
The getAll method will return, from the cache, a Map of the objects associated with the Collection of keys in argument "keys".
getAllWithLoader(Collection, Object) - Method in interface net.sf.ehcache.Ehcache
The getAll method will return, from the cache, a Map of the objects associated with the Collection of keys in argument "keys".
getAndReset() - Method in interface net.sf.ehcache.util.counter.sampled.SampledCounter
Returns the current value of the counter and resets it to 0
getAndReset() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
Returns the current value of the counter and resets it to 0
getAndReset() - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
Returns the current value of the counter and resets it to 0
getAndSet(long) - Method in interface net.sf.ehcache.util.counter.Counter
Returns the value of the counter and sets it to the new value
getAndSet(long) - Method in class net.sf.ehcache.util.counter.CounterImpl
Returns the value of the counter and sets it to the new value
getAndSet(long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
throws UnsupportedOperationException
getApproximateDiskByteSize() - Method in interface net.sf.ehcache.pool.PoolableStore
Return the approximate disk size in bytes
getApproximateDiskByteSize() - Method in class net.sf.ehcache.store.disk.DiskStore
Return the approximate disk size in bytes
getApproximateDiskByteSize() - Method in class net.sf.ehcache.store.MemoryStore
Return the approximate disk size in bytes
getApproximateDiskCountSize() - Method in interface net.sf.ehcache.pool.PoolableStore
Return the approximate disk size
getApproximateDiskCountSize() - Method in class net.sf.ehcache.store.disk.DiskStore
Return the approximate disk size
getApproximateDiskCountSize() - Method in class net.sf.ehcache.store.MemoryStore
Return the approximate disk size
getApproximateDiskHitRate() - Method in interface net.sf.ehcache.pool.PoolableStore
Return the approximate disk hit rate
getApproximateDiskHitRate() - Method in class net.sf.ehcache.store.disk.DiskStore
Return the approximate disk hit rate
getApproximateDiskHitRate() - Method in class net.sf.ehcache.store.MemoryStore
Return the approximate disk hit rate
getApproximateDiskMissRate() - Method in interface net.sf.ehcache.pool.PoolableStore
Return the approximate disk miss rate
getApproximateDiskMissRate() - Method in class net.sf.ehcache.store.disk.DiskStore
Return the approximate disk miss rate
getApproximateDiskMissRate() - Method in class net.sf.ehcache.store.MemoryStore
Return the approximate disk miss rate
getApproximateHeapByteSize() - Method in interface net.sf.ehcache.pool.PoolableStore
Return the approximate heap size in bytes
getApproximateHeapByteSize() - Method in class net.sf.ehcache.store.disk.DiskStore
Return the approximate heap size in bytes
getApproximateHeapByteSize() - Method in class net.sf.ehcache.store.MemoryStore
Return the approximate heap size in bytes
getApproximateHeapCountSize() - Method in interface net.sf.ehcache.pool.PoolableStore
Return the approximate heap size
getApproximateHeapCountSize() - Method in class net.sf.ehcache.store.disk.DiskStore
Return the approximate heap size
getApproximateHeapCountSize() - Method in class net.sf.ehcache.store.MemoryStore
Return the approximate heap size
getApproximateHeapHitRate() - Method in interface net.sf.ehcache.pool.PoolableStore
Return the approximate heap hit rate
getApproximateHeapHitRate() - Method in class net.sf.ehcache.store.disk.DiskStore
Return the approximate heap hit rate
getApproximateHeapHitRate() - Method in class net.sf.ehcache.store.MemoryStore
Return the approximate heap hit rate
getApproximateHeapMissRate() - Method in interface net.sf.ehcache.pool.PoolableStore
Return the approximate heap miss rate
getApproximateHeapMissRate() - Method in class net.sf.ehcache.store.disk.DiskStore
Return the approximate heap miss rate
getApproximateHeapMissRate() - Method in class net.sf.ehcache.store.MemoryStore
Return the approximate heap miss rate
getAssociatedCache() - Method in class net.sf.ehcache.Statistics
 
getAssociatedCacheName() - Method in class net.sf.ehcache.management.CacheStatistics
 
getAssociatedCacheName() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
 
getAssociatedCacheName() - Method in class net.sf.ehcache.Statistics
 
getAttribute(String) - Method in class net.sf.ehcache.management.Store
getAttribute() - Method in interface net.sf.ehcache.search.aggregator.AggregatorInstance
Get the attribute to pass to aggregator
getAttribute() - Method in class net.sf.ehcache.search.aggregator.Average
Get the attribute to pass to aggregator
getAttribute() - Method in class net.sf.ehcache.search.aggregator.Count
Get the attribute to pass to aggregator
getAttribute() - Method in class net.sf.ehcache.search.aggregator.Max
Get the attribute to pass to aggregator
getAttribute() - Method in class net.sf.ehcache.search.aggregator.Min
Get the attribute to pass to aggregator
getAttribute() - Method in class net.sf.ehcache.search.aggregator.Sum
Get the attribute to pass to aggregator
getAttribute(Attribute<T>) - Method in class net.sf.ehcache.search.impl.BaseResult
Retrieve the given attribute value for this cache entry
getAttribute(Attribute<T>) - Method in interface net.sf.ehcache.search.Result
Retrieve the given attribute value for this cache entry
getAttribute() - Method in interface net.sf.ehcache.store.StoreQuery.Ordering
Attribute to order by
getAttributeName() - Method in class net.sf.ehcache.search.Attribute
Get the attribute name
getAttributeName() - Method in class net.sf.ehcache.search.expression.ComparableValue
Attribute name.
getAttributeName() - Method in class net.sf.ehcache.search.expression.EqualTo
Get attribute name.
getAttributeName() - Method in class net.sf.ehcache.search.expression.ILike
Return attribute name.
getAttributeName() - Method in class net.sf.ehcache.search.expression.InCollection
Return attributeName
getAttributes() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
List of attributes of this element
getAttributes() - Method in interface net.sf.ehcache.config.generator.model.NodeElement
List of attributes of this element
getAttributes(String[]) - Method in class net.sf.ehcache.management.Store
getAverageGetTime() - Method in class net.sf.ehcache.Cache
The average get time in ms.
getAverageGetTime() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
The average get time in ms.
getAverageGetTime() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
The average get time in ms.
getAverageGetTime() - Method in interface net.sf.ehcache.Ehcache
The average get time in ms.
getAverageGetTime() - Method in class net.sf.ehcache.Statistics
The average get time.
getAverageGetTimeMillis(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Return average time taken in milliseconds for a get operation for the input cache name
getAverageGetTimeMillis(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Return average time taken in milliseconds for a get operation for the input cache name
getAverageGetTimeMillis(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Return average time taken in milliseconds for a get operation for the input cache name
getAverageGetTimeMillis() - Method in class net.sf.ehcache.management.sampled.SampledCache
Average time in milli seconds taken to get an element from the cache.
getAverageGetTimeMillis() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Average time in milli seconds taken to get an element from the cache.
getAverageGetTimeMillis() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Average time in milli seconds taken to get an element from the cache.
getAverageGetTimeMillis() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Average time in milli seconds taken to get an element from the cache.
getAverageGetTimeMillis() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Average time in milli seconds taken to get an element from the cache.
getAverageGetTimeMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for average time taken for get() operation in the cache
getAverageGetTimeMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for average time taken for get() operation in the cache
getAverageGetTimeMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for average time taken for get() operation in the cache
getAverageGetTimeMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for average time taken for get() operation in the cache
getAverageGetTimeMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for average time taken for get() operation in the cache
getAverageSearchTime() - Method in class net.sf.ehcache.Cache
Get the average search execution time (in millis) for searches that have completed in the last sample period
getAverageSearchTime() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Get the average search execution time (in millis) for searches that have completed in the last sample period
getAverageSearchTime() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Get the average search execution time (in millis) for searches that have completed in the last sample period
getAverageSearchTime() - Method in interface net.sf.ehcache.Ehcache
Get the average search execution time (in millis) for searches that have completed in the last sample period
getAverageSearchTime() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get the average search execution time for searches finishing within the last sample period
getAverageSearchTime() - Method in class net.sf.ehcache.Statistics
Gets the average execution time (in milliseconds) within the last sample period
getAverageSearchTime() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get the average search execution time for searches finishing within the last sample period
getAverageSearchTime() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get the average search execution time for searches finishing within the last sample period
getAverageSearchTime() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get the average search execution time for searches finishing within the last sample period
getAverageSearchTime() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get the average search execution time for searches finishing within the last sample period
getBeanProperty(Object, String) - Static method in class net.sf.ehcache.hibernate.management.impl.BeanUtils
Retrieve a named bean property value.
getBootstrapCacheLoader() - Method in class net.sf.ehcache.Cache
Accessor for the BootstrapCacheLoader associated with this cache.
getBootstrapCacheLoader() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Accessor for the BootstrapCacheLoader associated with this cache.
getBootstrapCacheLoader() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Accessor for the BootstrapCacheLoader associated with this cache.
getBootstrapCacheLoader() - Method in interface net.sf.ehcache.Ehcache
Accessor for the BootstrapCacheLoader associated with this cache.
getBootstrapCacheLoaderFactoryConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getBoundCachePeers() - Method in interface net.sf.ehcache.distribution.CacheManagerPeerListener
All of the caches which are listening for remote changes.
getBoundCachePeers() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
All of the caches which are listening for remote changes.
getBranchQualifier() - Method in class net.sf.ehcache.transaction.xa.SerializableXid
getBuildHostname() - Method in class net.sf.ehcache.util.ProductInfo
 
getBuildJdk() - Method in class net.sf.ehcache.util.ProductInfo
 
getBuildRevision() - Method in class net.sf.ehcache.util.ProductInfo
 
getBuildTime() - Method in class net.sf.ehcache.util.ProductInfo
 
getBuiltBy() - Method in class net.sf.ehcache.util.ProductInfo
 
getBulkOpsTimeoutMultiplyFactor() - Method in class net.sf.ehcache.config.NonstopConfiguration
returns the time out multiplication factor for bulk cache operations
getBytes() - Method in class net.sf.ehcache.util.MemoryEfficientByteArrayOutputStream
Gets the bytes.
getCache(String) - Method in class net.sf.ehcache.CacheManager
Returns a concrete implementation of Cache, it it is available in the CacheManager.
getCache() - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Retrieve the EHCache backing cache
getCache(String) - Method in class net.sf.ehcache.management.CacheManager
Returns a JMX Cache bean
getCache(String) - Method in interface net.sf.ehcache.management.CacheManagerMBean
Returns a JMX Cache bean
getCache() - Method in interface net.sf.ehcache.store.StoreQuery
Get the cache this query originated from
getCacheAttributes() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheAttributes
getCacheAverageGetTime() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheAverageGetTime() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheAverageGetTime() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheAverageGetTime() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheAverageSearchTime() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheAverageSearchTime() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheAverageSearchTime() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheAverageSearchTime() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheCluster() - Method in class net.sf.ehcache.terracotta.TerracottaClient
Get the CacheCluster associated with this client
getCacheConfiguration() - Method in class net.sf.ehcache.Cache
Gets the cache configuration this cache was created with.
getCacheConfiguration() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets the cache configuration this cache was created with.
getCacheConfiguration() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets the cache configuration this cache was created with.
getCacheConfiguration() - Method in interface net.sf.ehcache.Ehcache
Gets the cache configuration this cache was created with.
getCacheConfiguration() - Method in class net.sf.ehcache.management.Cache
Gets the JMX read-only CacheConfiguration
getCacheConfiguration() - Method in interface net.sf.ehcache.management.CacheMBean
Gets the JMX read-only CacheConfiguration
getCacheConfigurations() - Method in class net.sf.ehcache.config.Configuration
Gets a Map of cache configurations, keyed by name.
getCacheConfigurationsKeySet() - Method in class net.sf.ehcache.config.Configuration
Gets a Map of cacheConfigurations.
getCacheDataDescription() - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
getCacheDecoratorConfigurations() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getCacheElementEvictedMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value element evicted from cache
getCacheElementEvictedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value element evicted from cache
getCacheElementEvictedMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value element evicted from cache
getCacheElementEvictedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value element evicted from cache
getCacheElementEvictedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value element evicted from cache
getCacheElementExpiredMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value element expired from cache
getCacheElementExpiredMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value element expired from cache
getCacheElementExpiredMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value element expired from cache
getCacheElementExpiredMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value element expired from cache
getCacheElementExpiredMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value element expired from cache
getCacheElementPutMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value element puts in the cache
getCacheElementPutMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value element puts in the cache
getCacheElementPutMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value element puts in the cache
getCacheElementPutMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value element puts in the cache
getCacheElementPutMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value element puts in the cache
getCacheElementRemovedMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value element removed from cache
getCacheElementRemovedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value element removed from cache
getCacheElementRemovedMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value element removed from cache
getCacheElementRemovedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value element removed from cache
getCacheElementRemovedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value element removed from cache
getCacheElementUpdatedMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value element updates , i.e.
getCacheElementUpdatedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value element updates , i.e.
getCacheElementUpdatedMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value element updates , i.e.
getCacheElementUpdatedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value element updates , i.e.
getCacheElementUpdatedMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value element updates , i.e.
getCacheEventListenerConfigurations() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getCacheEventListeners() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Gets a copy of the set of the listeners registered to this class
getCacheEventNotificationService() - Method in class net.sf.ehcache.Cache
Use this to access the service in order to register and unregister listeners
getCacheEventNotificationService() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Use this to access the service in order to register and unregister listeners
getCacheEventNotificationService() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Use this to access the service in order to register and unregister listeners
getCacheEventNotificationService() - Method in interface net.sf.ehcache.Ehcache
Use this to access the service in order to register and unregister listeners
getCacheEventReplicator() - Method in interface net.sf.ehcache.constructs.nonstop.NonstopActiveDelegateHolder
Returns the cache event replicator
getCacheEvictionRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheEvictionRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheEvictionRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheEvictionRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheExceptionHandler() - Method in class net.sf.ehcache.Cache
Gets the ExceptionHandler on this Cache, or null if there isn't one.
getCacheExceptionHandler() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Sets an ExceptionHandler on the Cache.
getCacheExceptionHandler() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Sets an ExceptionHandler on the Cache.
getCacheExceptionHandler() - Method in interface net.sf.ehcache.Ehcache
Sets an ExceptionHandler on the Cache.
getCacheExceptionHandlerFactoryConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getCacheExpirationRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheExpirationRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheExpirationRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheExpirationRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheExtensionConfigurations() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getCacheHitCount() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns hit count for all the caches
getCacheHitCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns hit count for all the caches
getCacheHitCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns hit count for all the caches
getCacheHitCount() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getCacheHitCount
getCacheHitCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
The number of times a requested item was found in the cache.
getCacheHitCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
The number of times a requested item was found in the cache.
getCacheHitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
The number of times a requested item was found in the cache.
getCacheHitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
The number of times a requested item was found in the cache.
getCacheHitCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
The number of times a requested item was found in the cache.
getCacheHitInMemoryMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for in-memory cache hit
getCacheHitInMemoryMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for in-memory cache hit
getCacheHitInMemoryMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for in-memory cache hit
getCacheHitInMemoryMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for in-memory cache hit
getCacheHitInMemoryMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for in-memory cache hit
getCacheHitMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for cache hit
getCacheHitMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for cache hit
getCacheHitMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for cache hit
getCacheHitMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for cache hit
getCacheHitMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for cache hit
getCacheHitOffHeapMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for off-heap cache hit
getCacheHitOffHeapMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for off-heap cache hit
getCacheHitOffHeapMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for off-heap cache hit
getCacheHitOffHeapMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for off-heap cache hit
getCacheHitOffHeapMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for off-heap cache hit
getCacheHitOnDiskMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for on-disk cache hit
getCacheHitOnDiskMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for on-disk cache hit
getCacheHitOnDiskMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for on-disk cache hit
getCacheHitOnDiskMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for on-disk cache hit
getCacheHitOnDiskMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for on-disk cache hit
getCacheHitPercentage() - Method in class net.sf.ehcache.management.CacheStatistics
Returns the percentage of cache accesses that found a requested item in the cache.
getCacheHitPercentage() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Returns the percentage of cache accesses that found a requested item in the cache.
getCacheHitRate() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns hit rate for all the caches
getCacheHitRate() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns hit rate for all the caches
getCacheHitRate() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns hit rate for all the caches
getCacheHitRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheHitRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheHitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheHitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheHits() - Method in class net.sf.ehcache.management.CacheStatistics
The number of times a requested item was found in the cache.
getCacheHits() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
The number of times a requested item was found in the cache.
getCacheHits() - Method in class net.sf.ehcache.Statistics
The number of times a requested item was found in the cache.
getCacheHitSample() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns hit count sample for all the caches
getCacheHitSample() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns hit count sample for all the caches
getCacheHitSample() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns hit count sample for all the caches
getCacheInMemoryHitRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheInMemoryHitRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheInMemoryHitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheInMemoryHitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheInMemoryMissRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheInMemoryMissRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheInMemoryMissRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheInMemoryMissRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheLoaderConfigurations() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getCacheLoaderTimeoutMillis() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getCacheManager() - Method in class net.sf.ehcache.Cache
Gets the CacheManager managing this cache.
getCacheManager(String) - Static method in class net.sf.ehcache.CacheManager
Checks if a cacheManager already exists for a given name and gets it.
getCacheManager() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets the CacheManager managing this cache.
getCacheManager() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets the CacheManager managing this cache.
getCacheManager() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
The cacheManager this provider is bound to
getCacheManager() - Method in interface net.sf.ehcache.Ehcache
Gets the CacheManager managing this cache.
getCacheManagerAttributes() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
getCacheManagerAttributes
getCacheManagerEventListener() - Method in class net.sf.ehcache.CacheManager
Returns the composite listener.
getCacheManagerEventListenerFactoryConfiguration() - Method in class net.sf.ehcache.config.Configuration
Gets the CacheManagerEventListener factory configuration.
getCacheManagerEventListenerRegistry() - Method in class net.sf.ehcache.CacheManager
Gets the CacheManagerEventListenerRegistry.
getCacheManagerName() - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
 
getCacheManagerName() - Method in class net.sf.ehcache.transaction.TransactionIDSerializedForm
Get the name of the cache manager which contains the factory that created the original TransactionID
getCacheManagerName() - Method in class net.sf.ehcache.transaction.XidTransactionIDSerializedForm
Get the name of the cache manager which contains the factory that created the original XidTransactionID
getCacheManagerObjectName(String, String) - Static method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMbeanNames
Returns an ObjectName for the passed name
getCacheManagerObjectName(String, String) - Static method in class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
Returns an ObjectName for the passed cacheManagerName
getCacheManagerPeerListenerFactoryConfigurations() - Method in class net.sf.ehcache.config.Configuration
Gets the CacheManagerPeerListener factory configuration.
getCacheManagerPeerProvider(String) - Method in class net.sf.ehcache.CacheManager
Gets the CacheManagerPeerProvider, matching the given scheme For distributed caches, the peer provider finds other cache managers and their caches in the same cluster
getCacheManagerPeerProviderFactoryConfiguration() - Method in class net.sf.ehcache.config.Configuration
Gets the CacheManagerPeerProvider factory configuration.
getCacheManagerPeerProviders() - Method in class net.sf.ehcache.CacheManager
 
getCacheMetrics() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheMetrics() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Get a map of cache name to performance metrics (hits, misses).
getCacheMissCount() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns miss count for all the caches
getCacheMissCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns miss count for all the caches
getCacheMissCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns miss count for all the caches
getCacheMissCount() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getCacheMissCount
getCacheMissCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of times a requested element was not found in the cache.
getCacheMissCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of times a requested element was not found in the cache.
getCacheMissCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of times a requested element was not found in the cache.
getCacheMissCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of times a requested element was not found in the cache.
getCacheMissCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of times a requested element was not found in the cache.
getCacheMissCountExpired() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheMissCountExpired() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
 
getCacheMissCountExpired() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
getCacheMissCountExpired() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
getCacheMissCountExpired() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
getCacheMisses() - Method in class net.sf.ehcache.management.CacheStatistics
Warning.
getCacheMisses() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
 
getCacheMisses() - Method in class net.sf.ehcache.Statistics
 
getCacheMissExpiredMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for cache miss as result of the element getting expired
getCacheMissExpiredMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for cache miss as result of the element getting expired
getCacheMissExpiredMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for cache miss as result of the element getting expired
getCacheMissExpiredMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for cache miss as result of the element getting expired
getCacheMissExpiredMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for cache miss as result of the element getting expired
getCacheMissInMemoryMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for in-memory cache miss
getCacheMissInMemoryMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for in-memory cache miss
getCacheMissInMemoryMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for in-memory cache miss
getCacheMissInMemoryMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for in-memory cache miss
getCacheMissInMemoryMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for in-memory cache miss
getCacheMissMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for cache miss
getCacheMissMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for cache miss
getCacheMissMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for cache miss
getCacheMissMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for cache miss
getCacheMissMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for cache miss
getCacheMissNotFoundMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for cache miss as result of the element not found in cache
getCacheMissNotFoundMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for cache miss as result of the element not found in cache
getCacheMissNotFoundMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for cache miss as result of the element not found in cache
getCacheMissNotFoundMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for cache miss as result of the element not found in cache
getCacheMissNotFoundMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for cache miss as result of the element not found in cache
getCacheMissOffHeapMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for off-heap cache miss
getCacheMissOffHeapMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for off-heap cache miss
getCacheMissOffHeapMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for off-heap cache miss
getCacheMissOffHeapMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for off-heap cache miss
getCacheMissOffHeapMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for off-heap cache miss
getCacheMissOnDiskMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value for on-disk cache miss
getCacheMissOnDiskMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value for on-disk cache miss
getCacheMissOnDiskMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value for on-disk cache miss
getCacheMissOnDiskMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value for on-disk cache miss
getCacheMissOnDiskMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value for on-disk cache miss
getCacheMissPercentage() - Method in class net.sf.ehcache.management.CacheStatistics
Returns the percentage of cache accesses that did not find a requested element in the cache.
getCacheMissPercentage() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Returns the percentage of cache accesses that did not find a requested element in the cache.
getCacheMissRate() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns miss rate for all the caches
getCacheMissRate() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns miss rate for all the caches
getCacheMissRate() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns miss rate for all the caches
getCacheMissRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheMissRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheMissRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheMissRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheMissSample() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns miss count sample for all the caches
getCacheMissSample() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns miss count sample for all the caches
getCacheMissSample() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns miss count sample for all the caches
getCacheName() - Method in class net.sf.ehcache.config.CacheConfigError
Returns the cache name
getCacheName() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheName() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
 
getCacheName() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
getCacheName() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
getCacheName() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
getCacheName() - Method in interface net.sf.ehcache.transaction.xa.EhcacheXAResource
Getter to the name of the cache wrapped by this XAResource
getCacheName() - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
Getter to the name of the cache wrapped by this XAResource
getCacheNames() - Method in class net.sf.ehcache.CacheManager
Returns a list of the current cache names.
getCacheNames() - Method in class net.sf.ehcache.management.CacheManager
Gets the cache names managed by the CacheManager
getCacheNames() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Gets the cache names managed by the CacheManager
getCacheNames() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Gets the cache names managed by the CacheManager
getCacheNames() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Gets the cache names managed by the CacheManager
getCacheObjectName(String, String, String) - Static method in class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
Returns an ObjectName for the passed cacheManagerName, cacheName combination
getCacheOffHeapHitRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheOffHeapHitRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheOffHeapHitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheOffHeapHitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheOffHeapMissRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheOffHeapMissRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheOffHeapMissRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheOffHeapMissRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheOnDiskHitRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheOnDiskHitRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheOnDiskHitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheOnDiskHitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheOnDiskMissRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheOnDiskMissRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheOnDiskMissRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheOnDiskMissRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCachePeer() - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider.CachePeerEntry
 
getCachePeerListener(String) - Method in class net.sf.ehcache.CacheManager
When CacheManage is configured as part of a cluster, a CacheManagerPeerListener will be registered in it.
getCachePutCount() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns put count for all the caches
getCachePutCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns put count for all the caches
getCachePutCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns put count for all the caches
getCachePutCount() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getCachePutCount
getCachePutRate() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns put rate for all the caches
getCachePutRate() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns put rate for all the caches
getCachePutRate() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns put rate for all the caches
getCachePutRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCachePutRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCachePutRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCachePutRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCachePutSample() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns put count sample for all the caches
getCachePutSample() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns put count sample for all the caches
getCachePutSample() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns put count sample for all the caches
getCacheRegionStats() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns TabularData of cache region stats
getCacheRegionStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns TabularData of cache region stats
getCacheRegionStats() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns TabularData of cache region stats
getCacheRegionStats() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
 
getCacheRemoveRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheRemoveRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheRemoveRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheRemoveRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCaches() - Method in class net.sf.ehcache.management.CacheManager
Gets a list of caches in this CacheManager
getCaches() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Gets a list of caches in this CacheManager
getCacheSearchRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheSearchRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheSearchRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheSearchRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheUpdateRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getCacheUpdateRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getCacheUpdateRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getCacheUpdateRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getCacheWriterConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getCacheWriterFactoryConfiguration() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Accessor
getCacheXaCommitsMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value of XA commits
getCacheXaCommitsMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value of XA commits
getCacheXaCommitsMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value of XA commits
getCacheXaCommitsMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value of XA commits
getCacheXaCommitsMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value of XA commits
getCacheXaRollbacksMostRecentSample() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get most recent value of XA rollbacks
getCacheXaRollbacksMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get most recent value of XA rollbacks
getCacheXaRollbacksMostRecentSample() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get most recent value of XA rollbacks
getCacheXaRollbacksMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get most recent value of XA rollbacks
getCacheXaRollbacksMostRecentSample() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get most recent value of XA rollbacks
getCalculated() - Method in class net.sf.ehcache.pool.Size
Get the calculated size
getCause() - Method in exception net.sf.ehcache.writer.CacheWriterManagerException
getChildElements() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Returns the list of child elements.
getChildElements() - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Returns the list of child elements.
getClassName() - Method in class net.sf.ehcache.config.CopyStrategyConfiguration
Returns the fully qualified class name for the CopyStrategy to use
getClassName() - Method in class net.sf.ehcache.config.ElementValueComparatorConfiguration
Returns the fully qualified class name for the ElementValueComparator to use
getClassName() - Method in class net.sf.ehcache.config.SearchAttribute
Get the extractor class name
getCloseStatementCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns the count of close statements
getCloseStatementCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the count of close statements
getCloseStatementCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns the count of close statements
getCloseStatementCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns the count of close statements
getCluster(ClusterScheme) - Method in class net.sf.ehcache.CacheManager
Returns access to information about the cache cluster.
getClusteredInstanceFactory(Ehcache) - Method in class net.sf.ehcache.CacheManager
Return the clustered instance factory for a cache of this cache manager.
getClusteredInstanceFactory() - Method in class net.sf.ehcache.terracotta.TerracottaClient
Returns the ClusteredInstanceFactory associated with this client
getClusterOperation() - Method in interface net.sf.ehcache.constructs.nonstop.ClusterOperationCallable
Returns the ClusterOperation
getClusterUUID() - Method in class net.sf.ehcache.CacheManager
Returns unique cluster-wide id for this cache-manager.
getClusterUUID() - Method in class net.sf.ehcache.transaction.TransactionIDSerializedForm
Get the original TransactionID's cluster UUID
getCoherentReads() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Check whether coherent reads are enabled
getCollectionStats() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns TabularData of collection stats
getCollectionStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns TabularData of collection stats
getCollectionStats() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns TabularData of collection stats
getCollectionStats() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns TabularData of collection stats
getCommands() - Method in class net.sf.ehcache.transaction.xa.XATransactionContext
All ordered pending commands
getComparableValue() - Method in class net.sf.ehcache.search.expression.GreaterThan
Comparable value.
getComparableValue() - Method in class net.sf.ehcache.search.expression.GreaterThanOrEqual
Comparable value.
getComparableValue() - Method in class net.sf.ehcache.search.expression.LessThan
Comparable value.
getComparableValue() - Method in class net.sf.ehcache.search.expression.LessThanOrEqual
Comparable value.
getConcurrency() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Get the value of concurrency.
getConfiguration() - Method in class net.sf.ehcache.CacheManager
Get the CacheManager configuration
getConfiguration() - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
 
getConfigurationBean() - Method in class net.sf.ehcache.config.ConfigurationHelper
 
getConfigurationSource() - Method in class net.sf.ehcache.config.Configuration
Gets a description of the source from which this configuration was created.
getConfigurationSource(File) - Static method in class net.sf.ehcache.config.generator.ConfigurationSource
Utility factory method for creating a ConfigurationSource based on a file.
getConfigurationSource(URL) - Static method in class net.sf.ehcache.config.generator.ConfigurationSource
Utility factory method for creating a ConfigurationSource based on URL
getConfigurationSource(InputStream) - Static method in class net.sf.ehcache.config.generator.ConfigurationSource
Utility factory method for creating a ConfigurationSource based on InputStream
getConfigurationSource() - Static method in class net.sf.ehcache.config.generator.ConfigurationSource
Utility factory method for creating a ConfigurationSource based on default settings (default ehcache.xml in classpath if one is present or an ehcache-failsafe provided with the kit
getConfiguredRMISocketFactory() - Static method in class net.sf.ehcache.distribution.ConfigurableRMIClientSocketFactory
Return the JVM-level configured RMISocketFactory.
getConnectCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Return connect counts
getConnectCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Return connect counts
getConnectCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Return connect counts
getConnectCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Return connect counts
getConsistency() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Getter for consistency
getCopyStrategy() - Method in class net.sf.ehcache.config.CacheConfiguration
Getter to the CopyStrategy set in the config (really? how?).
getCopyStrategyConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Returns the copyStrategyConfiguration
getCopyStrategyInstance() - Method in class net.sf.ehcache.config.CopyStrategyConfiguration
Get (and potentially) instantiate the instance
getCount() - Method in class net.sf.ehcache.util.ratestatistics.AtomicRateStatistic
Returns the total number of events that have occurred in the lifetime of this statistic.
getCount() - Method in interface net.sf.ehcache.util.ratestatistics.RateStatistic
Returns the total number of events that have occurred in the lifetime of this statistic.
getCount() - Method in class net.sf.ehcache.util.ratestatistics.UnlockedRateStatistic
Returns the total number of events that have occurred in the lifetime of this statistic.
getCounterValue() - Method in class net.sf.ehcache.util.counter.sampled.TimeStampedCounterValue
Get the counter value
getCreationTime() - Method in class net.sf.ehcache.DefaultElementEvictionData
Get the element's creation time.
getCreationTime() - Method in class net.sf.ehcache.Element
Gets the creationTime of the Element
getCreationTime() - Method in interface net.sf.ehcache.ElementEvictionData
Get the element's creation time.
getCreationTime() - Method in class net.sf.ehcache.transaction.TransactionIDSerializedForm
Get the original TransactionID's creation time
getCreationTime() - Method in class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Retrieves the moment when the operation was created.
getCreationTime() - Method in interface net.sf.ehcache.writer.writebehind.operations.KeyBasedOperation
Retrieves the moment when the operation was created.
getCreationTime() - Method in class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Retrieves the moment when the operation was created.
getCriteria() - Method in class net.sf.ehcache.search.expression.Not
 
getCriteria() - Method in interface net.sf.ehcache.store.StoreQuery
Get the search criteria
getCriterion() - Method in class net.sf.ehcache.search.expression.And
Return criterion
getCriterion() - Method in class net.sf.ehcache.search.expression.Or
Return criteria
getCurrentNode() - Method in interface net.sf.ehcache.cluster.CacheCluster
Retrieves the ClusterNode instance that corresponds to the current node.
getCurrentNode() - Method in class net.sf.ehcache.cluster.NoopCacheCluster
Retrieves the ClusterNode instance that corresponds to the current node.
getCurrentNode() - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Retrieves the ClusterNode instance that corresponds to the current node.
getCurrentThreadLockContext() - Method in class net.sf.ehcache.constructs.nonstop.concurrency.ExplicitLockingContextThreadLocal
Returns the thread local for the current thread
getCurrentTransactionContext() - Method in interface net.sf.ehcache.transaction.xa.EhcacheXAResource
Gets the current XATransactionContext associated with this resource
getCurrentTransactionContext() - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
Gets the current XATransactionContext associated with this resource
getCurrentTransactionContext() - Method in class net.sf.ehcache.TransactionController
Get the transaction context bond to the current thread
getDataFile() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Return a reference to the data file backing this factory.
getDataFile() - Method in class net.sf.ehcache.store.disk.DiskStore
Return a reference to the data file backing this store.
getDate() - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider.CachePeerEntry
 
getDBSQLExecutionSample() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Not supported right now
getDBSQLExecutionSample() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Not supported right now
getDecision() - Method in class net.sf.ehcache.transaction.XidTransactionIDSerializedForm
Get the original XidTransactionID's decision
getDefaultCacheConfiguration() - Method in class net.sf.ehcache.config.Configuration
 
getDefaultPath() - Static method in class net.sf.ehcache.config.DiskStoreConfiguration
The diskStore default path, which is the system environment variable available on all Java virtual machines java.io.tmpdir
getDefaultTransactionTimeout() - Method in class net.sf.ehcache.TransactionController
Get the default transaction timeout in seconds
getDefaultTransactionTimeoutInSeconds() - Method in class net.sf.ehcache.config.Configuration
Get default transaction timeout
getDefaultValue() - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Returns the default value of the attribute
getDefaultValue() - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Returns the default value of the attribute
getDeleteCount() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
getDeleteCount
getDirection() - Method in interface net.sf.ehcache.store.StoreQuery.Ordering
Ordering direction
getDiskAccessStripes() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getDiskExpiryThreadIntervalSeconds() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getDiskExpiryThreadIntervalSeconds() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
getDiskExpiryThreadIntervalSeconds() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
getDiskExpiryThreadIntervalSeconds() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getDiskExpiryThreadIntervalSeconds() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getDiskHitRate() - Method in class net.sf.ehcache.store.disk.Segment
Return the disk hit rate
getDiskMissRate() - Method in class net.sf.ehcache.store.disk.Segment
Return the disk miss rate
getDiskSpoolBufferSizeMB() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getDiskSpoolBufferSizeMB() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
getDiskSpoolBufferSizeMB() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
getDiskStore() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Returns the underlying disk store for this legacy wrapper.
getDiskStoreConfiguration() - Method in class net.sf.ehcache.config.Configuration
Gets the disk store configuration.
getDiskStoreObjectCount() - Method in class net.sf.ehcache.management.CacheStatistics
Gets the number of objects in the DiskStore
getDiskStoreObjectCount() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Gets the number of objects in the DiskStore
getDiskStoreObjectCount() - Method in class net.sf.ehcache.Statistics
 
getDiskStorePath() - Method in class net.sf.ehcache.CacheManager
Returns the disk store path.
getDiskStorePath() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getDiskStorePath() - Method in class net.sf.ehcache.config.ConfigurationHelper
 
getDiskStoreSize() - Method in class net.sf.ehcache.Cache
Returns the number of elements in the disk store.
getDiskStoreSize() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns the number of elements in the disk store.
getDiskStoreSize() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns the number of elements in the disk store.
getDiskStoreSize() - Method in interface net.sf.ehcache.Ehcache
Returns the number of elements in the disk store.
getDynamicConfig() - Method in class net.sf.ehcache.config.Configuration
Get flag for dynamicConfig
getEhcache(String) - Method in class net.sf.ehcache.CacheManager
Gets an Ehcache

getEhcache() - Method in class net.sf.ehcache.distribution.EventMessage
Gets the associated Ehcache.
getEhcache() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
Return the Ehcache instance backing this Hibernate data region.
getEhcache() - Method in class net.sf.ehcache.management.CacheStatistics
Return the backing cache.
getElement() - Method in class net.sf.ehcache.CacheEntry
Retrieves the element of this cache entry.
getElement() - Method in class net.sf.ehcache.distribution.LegacyEventMessage
 
getElement() - Method in class net.sf.ehcache.distribution.RmiEventMessage
 
getElement(TransactionID) - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Get the element the current transaction is supposed to see.
getElement(TransactionID) - Method in interface net.sf.ehcache.transaction.SoftLock
Get the element the current transaction is supposed to see.
getElement() - Method in class net.sf.ehcache.transaction.xa.commands.StorePutCommand
Getter to the Element instance to be put in the Store
getElement() - Method in class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Retrieves the element that will be used for this operation
getElementComparatorInstance(CacheConfiguration) - Method in class net.sf.ehcache.config.ElementValueComparatorConfiguration
Get (and potentially) instantiate the instance
getElementCountInMemory() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated.  
getElementCountInMemory() - Method in class net.sf.ehcache.hibernate.management.impl.AggregateCacheRegionStats
 
getElementCountInMemory() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getElementCountInMemory() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
getElementCountOnDisk() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated.  
getElementCountOnDisk() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getElementCountOnDisk() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
getElementCountTotal() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getElementEvictionData() - Method in class net.sf.ehcache.Element
Retrieves this element's eviction data instance.
getElements(List) - Method in interface net.sf.ehcache.distribution.CachePeer
Gets a list of elements from the cache, for a list of keys, without updating Element statistics.
getElements(List) - Method in class net.sf.ehcache.distribution.RMICachePeer
Gets a list of elements from the cache, for a list of keys, without updating Element statistics.
getElements(List) - Method in class net.sf.ehcache.distribution.TransactionalRMICachePeer
 
getElementsEvictedCounter() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Gets the number of events, irrespective of whether there are any registered listeners.
getElementsExpiredCounter() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Gets the number of events, irrespective of whether there are any registered listeners.
getElementsPutCounter() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Gets the number of events, irrespective of whether there are any registered listeners.
getElementsRemoveAllCounter() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Gets the number of events, irrespective of whether there are any registered listeners.
getElementsRemovedCounter() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Gets the number of events, irrespective of whether there are any registered listeners.
getElementsUpdatedCounter() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Gets the number of events, irrespective of whether there are any registered listeners.
getElementValueComparatorConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Returns the elementComparatorConfiguration
getEmbeddedConfig() - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Get the embedded config read as
getEntityStats() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns TabularData of entity stats
getEntityStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns TabularData of entity stats
getEntityStats() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns TabularData of entity stats
getEntityStats() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns TabularData of entity stats
getEntry() - Method in class net.sf.ehcache.transaction.xa.commands.StoreRemoveCommand
Getter to the cache entry to be removed
getEntry() - Method in class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Retrieves the entry that will be used for this operation
getError() - Method in class net.sf.ehcache.config.ConfigError
Access error message
getEvent() - Method in class net.sf.ehcache.distribution.LegacyEventMessage
Gets the event.
getEventListenerList() - Method in class net.sf.ehcache.store.AbstractStore
onLoad initializer
getEvictedCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of elements evicted from the cache
getEvictedCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of elements evicted from the cache
getEvictedCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of elements evicted from the cache
getEvictedCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of elements evicted from the cache
getEvictedCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of elements evicted from the cache
getEvictionCount() - Method in class net.sf.ehcache.Statistics
Gets the number of cache evictions, since the cache was created, or statistics were cleared.
getEvictionPolicy() - Method in class net.sf.ehcache.store.LruMemoryStore
 
getEvictor() - Method in class net.sf.ehcache.pool.impl.AbstractPool
Return the pool evictor used by this pool.
getEvictor() - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Return the pool evictor used by this pool.
getEvictor() - Method in interface net.sf.ehcache.pool.Pool
Return the pool evictor used by this pool.
getExecutionAvgTime() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getExecutionAvgTime
getExecutionCount() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getExecutionCount
getExecutionMaxTime() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getExecutionMaxTime
getExecutionMinTime() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getExecutionMinTime
getExecutionRowCount() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getExecutionRowCount
getExpirationTime() - Method in class net.sf.ehcache.Element
Returns the expiration time based on time to live.
getExpiredCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of elements expired since creation or last clear
getExpiredCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of elements expired since creation or last clear
getExpiredCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of elements expired since creation or last clear
getExpiredCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of elements expired since creation or last clear
getExpiredCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of elements expired since creation or last clear
getExpression() - Method in class net.sf.ehcache.config.SearchAttribute
Get the attribute expression
getFactory() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory.DiskSubstitute
Returns the DiskStorageFactory instance that generated this DiskSubstitute
getFactoryConfiguration() - Method in class net.sf.ehcache.config.generator.model.elements.FactoryConfigurationElement
Returns the FactoryConfiguration associated with this element
getFallbackClassLoader() - Static method in class net.sf.ehcache.util.ClassLoaderUtil
Gets a fallback ClassLoader that all classes in ehcache, and extensions, should use for classloading.
getFetchCount() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
getFetchCount
getFetchCount() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
getFetchCount
getFieldOffsetAdjustment() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
The size of the jvm-specific field offset adjustment in bytes.
getFileSize() - Method in class net.sf.ehcache.store.disk.ods.FileAllocationTree
Return the current occupied size of this file.
getFlushCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns flush count
getFlushCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns flush count
getFlushCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns flush count
getFlushCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns flush count
getFormatId() - Method in class net.sf.ehcache.transaction.xa.SerializableXid
getFQName() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Same as calling NodeElement.getFQName(String) with the string "."
getFQName(String) - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
The fully qualified name of the element.
getFQName() - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Same as calling NodeElement.getFQName(String) with the string "."
getFQName(String) - Method in interface net.sf.ehcache.config.generator.model.NodeElement
The fully qualified name of the element.
getFreePort() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Gets a free server socket port.
getFrontEndCacheTier() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Returns the FrontEndCacheTier this RegisteredEventListeners is backing, or null if the cache isn't backed by one
getFrozenElement() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Get the Element with which this soft lock should be replaced by a commit, rollback or clean up
getFrozenElement() - Method in interface net.sf.ehcache.transaction.SoftLock
Get the Element with which this soft lock should be replaced by a commit, rollback or clean up
getFullyQualifiedClassPath() - Method in class net.sf.ehcache.config.FactoryConfiguration
Getter.
getGlobalTransactionId() - Method in class net.sf.ehcache.transaction.xa.SerializableXid
getGuid() - Method in class net.sf.ehcache.Cache
The GUID for this cache instance can be used to determine whether two cache instance references are pointing to the same cache.
getGuid() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
The GUID for this cache instance can be used to determine whether two cache instance references are pointing to the same cache.
getGuid() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
The GUID for this cache instance can be used to determine whether two cache instance references are pointing to the same cache.
getGuid() - Method in interface net.sf.ehcache.distribution.CachePeer
Gets the globally unique id for the underlying Cache instance.
getGuid() - Method in class net.sf.ehcache.distribution.RMICachePeer
Gets the globally unique id for the underlying Cache instance.
getGuid() - Method in interface net.sf.ehcache.Ehcache
The GUID for this cache instance can be used to determine whether two cache instance references are pointing to the same cache.
getHasWriteBehindWriter() - Method in class net.sf.ehcache.management.sampled.SampledCache
Is there a registered Write-behind CacheWriter
getHasWriteBehindWriter() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Returns whether any caches are configured for write-behind
getHasWriteBehindWriter() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Returns whether any caches are configured for write-behind
getHasWriteBehindWriter() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Is there a registered Write-behind CacheWriter
getHeartBeatInterval() - Static method in class net.sf.ehcache.distribution.MulticastKeepaliveHeartbeatSender
Returns the heartbeat interval.
getHeartBeatReceiver() - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
 
getHeartBeatSender() - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
 
getHistorySize() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterConfig
Returns the history size
getHitCount() - Method in class net.sf.ehcache.Element
Gets the hit count on this element.
getHitCount() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getHitRatio() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getHostname() - Method in interface net.sf.ehcache.cluster.ClusterNode
Get the host name of the node
getHostname() - Method in class net.sf.ehcache.terracotta.DisconnectedClusterNode
Get the host name of the node
getId() - Method in interface net.sf.ehcache.cluster.ClusterNode
Get a unique (per cluster) identifier for this node.
getId() - Method in class net.sf.ehcache.terracotta.DisconnectedClusterNode
Get a unique (per cluster) identifier for this node.
getId() - Method in class net.sf.ehcache.transaction.TransactionIDSerializedForm
Get the original TransactionID's internal ID
getIndexFile() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Return the index file for this store.
getIndexFile() - Method in class net.sf.ehcache.store.disk.DiskStore
Return a reference to the index file for this store.
getInitialValue() - Method in class net.sf.ehcache.util.counter.CounterConfig
Gets the initial value
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
.
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
.
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
.
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.store.disk.DiskStore
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.store.FrontEndCacheTier
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.store.LruMemoryStore
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.store.MemoryOnlyStore
{inheritDoc}
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.store.MemoryStore
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.store.NullStore
getInMemoryEvictionPolicy() - Method in interface net.sf.ehcache.store.Store
 
getInMemoryEvictionPolicy() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
getInMemoryHitCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of times a requested item was found in the Memory Store.
getInMemoryHitCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of times a requested item was found in the Memory Store.
getInMemoryHitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of times a requested item was found in the Memory Store.
getInMemoryHitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of times a requested item was found in the Memory Store.
getInMemoryHitCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of times a requested item was found in the Memory Store.
getInMemoryHitPercentage() - Method in class net.sf.ehcache.management.CacheStatistics
Returns the percentage of cache accesses that found a requested item cached in-memory.
getInMemoryHitPercentage() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Returns the percentage of cache accesses that found a requested item cached in-memory.
getInMemoryHits() - Method in class net.sf.ehcache.management.CacheStatistics
Number of times a requested item was found in the Memory Store.
getInMemoryHits() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Number of times a requested item was found in the Memory Store.
getInMemoryHits() - Method in class net.sf.ehcache.Statistics
Number of times a requested item was found in the Memory Store.
getInMemoryMissCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of times a requested item was not found in the Memory Store.
getInMemoryMissCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of times a requested item was not found in the Memory Store.
getInMemoryMissCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of times a requested item was not found in the Memory Store.
getInMemoryMissCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of times a requested item was not found in the Memory Store.
getInMemoryMissCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of times a requested item was not found in the Memory Store.
getInMemoryMisses() - Method in class net.sf.ehcache.management.CacheStatistics
getInMemoryMisses() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
 
getInMemoryMisses() - Method in class net.sf.ehcache.Statistics
Number of times a requested item was not found in the Memory Store.
getInMemorySize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.management.sampled.SampledCache
Deprecated. use SampledCache.getLocalHeapSize()
getInMemorySize() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Deprecated. use LiveCacheStatistics.getLocalHeapSize()
getInMemorySize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Deprecated. see LiveCacheStatisticsImpl.getLocalHeapSize()
getInMemorySize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Deprecated. see LiveCacheStatisticsWrapper.getLocalHeapSize()
getInMemorySize() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Deprecated. see NullLiveCacheStatisticsData.getLocalHeapSize()
getInMemorySize() - Method in class net.sf.ehcache.store.disk.DiskStore
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.store.LruMemoryStore
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.store.MemoryStore
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.store.NullStore
Returns the current local in-memory store size
getInMemorySize() - Method in interface net.sf.ehcache.store.Store
Returns the current local in-memory store size
getInMemorySize() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Returns the current local in-memory store size
getInMemorySizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.store.disk.DiskStore
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.store.LruMemoryStore
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.store.MemoryStore
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.store.NullStore
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in interface net.sf.ehcache.store.Store
Gets the size of the in-memory portion of the store, in bytes.
getInMemorySizeInBytes() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Gets the size of the in-memory portion of the store, in bytes.
getInnerContent() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
The inner content of this element as string.
getInnerContent() - Method in interface net.sf.ehcache.config.generator.model.NodeElement
The inner content of this element as string.
getInsertCount() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
getInsertCount
getInstance() - Static method in class net.sf.ehcache.CacheManager
A factory method to create a singleton CacheManager with default config, or return it if it exists.
getInstance() - Static method in class net.sf.ehcache.constructs.nonstop.CacheManagerExecutorServiceFactory
Returns the singleton instance
getInstance() - Static method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
returns the singleton instance
getInstance() - Static method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns the singleton instance
getInstance() - Static method in class net.sf.ehcache.hibernate.nonstop.HibernateNonstopCacheExceptionHandler
Returns the singleton instance
getInstance() - Static method in class net.sf.ehcache.writer.writebehind.CastingOperationConverter
Singleton retriever static method
getInternalContext() - Method in class net.sf.ehcache.Cache
This should not be used return some internal context (generally will be null)
getInternalContext() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
This should not be used return some internal context (generally will be null)
getInternalContext() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
This should not be used return some internal context (generally will be null)
getInternalContext() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
This should not be used, and will generally return null
getInternalContext() - Method in interface net.sf.ehcache.Ehcache
This should not be used return some internal context (generally will be null)
getInternalContext() - Method in class net.sf.ehcache.store.disk.DiskStore
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.store.FrontEndCacheTier
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.store.LruMemoryStore
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.store.MemoryStore
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.store.NullStore
This should not be used, and will generally return null
getInternalContext() - Method in interface net.sf.ehcache.store.Store
This should not be used, and will generally return null
getInternalContext() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
This should not be used, and will generally return null
getIntervalMillis() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
Returns the sampling thread interval in millis
getIntervalSecs() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterConfig
Returns the interval time (seconds)
getIp() - Method in interface net.sf.ehcache.cluster.ClusterNode
Get the IP address of the node
getIp() - Method in class net.sf.ehcache.terracotta.DisconnectedClusterNode
Get the IP address of the node
getJavaPointerSize() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Size of a java pointer in bytes on this runtime (that differs when compressedOops are being used)
getJvmDescription() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
A human-readable description of the JVM and its relevant enabled options.Os
getKey() - Method in class net.sf.ehcache.CacheEntry
Retrieves the key of this cache entry.
getKey() - Method in class net.sf.ehcache.Element
Gets the key attribute of the Element object.
getKey() - Method in class net.sf.ehcache.search.impl.BaseResult
Return the key for this cache entry.
getKey() - Method in interface net.sf.ehcache.search.Result
Return the key for this cache entry.
getKey() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Get the key of the element this soft lock is guarding
getKey() - Method in interface net.sf.ehcache.transaction.SoftLock
Get the key of the element this soft lock is guarding
getKey() - Method in class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Retrieves the element key for this operation.
getKey() - Method in interface net.sf.ehcache.writer.writebehind.operations.KeyBasedOperation
Retrieves the element key for this operation.
getKey() - Method in class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Retrieves the element key for this operation.
getKeys() - Method in class net.sf.ehcache.Cache
Returns a list of all element keys in the cache, whether or not they are expired.
getKeys() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns a list of all elements in the cache, whether or not they are expired.
getKeys() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns a list of all elements in the cache, whether or not they are expired.
getKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in interface net.sf.ehcache.distribution.CachePeer
Returns a list of all elements in the cache, whether or not they are expired.
getKeys() - Method in class net.sf.ehcache.distribution.RMICachePeer
Returns a list of all elements in the cache, whether or not they are expired.
getKeys() - Method in class net.sf.ehcache.distribution.TransactionalRMICachePeer
 
getKeys() - Method in interface net.sf.ehcache.Ehcache
Returns a list of all elements in the cache, whether or not they are expired.
getKeys() - Method in class net.sf.ehcache.store.disk.DiskStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.store.LruMemoryStore
Gets an Array of the keys for all elements in the memory cache.
getKeys() - Method in class net.sf.ehcache.store.MemoryStore
Gets an Array of the keys for all elements in the memory cache.
getKeys() - Method in class net.sf.ehcache.store.NullStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in interface net.sf.ehcache.store.Store
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Gets an Array of the keys for all elements in the disk store.
getKeys() - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Gets an Array of the keys for all elements in the disk store.
getKeysInvisibleInContext(LocalTransactionContext) - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockFactoryImpl
Get a Set of keys protected by soft locks which must not be visible to a transaction context according to the isolation level.
getKeysInvisibleInContext(LocalTransactionContext) - Method in interface net.sf.ehcache.transaction.SoftLockFactory
Get a Set of keys protected by soft locks which must not be visible to a transaction context according to the isolation level.
getKeysNoDuplicateCheck() - Method in class net.sf.ehcache.Cache
Returns a list of all elements in the cache, whether or not they are expired.
getKeysNoDuplicateCheck() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns a list of all elements in the cache, whether or not they are expired.
getKeysNoDuplicateCheck() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns a list of all elements in the cache, whether or not they are expired.
getKeysNoDuplicateCheck() - Method in interface net.sf.ehcache.Ehcache
Deprecated. versions since 2.1 do not return duplicates
getKeysWithExpiryCheck() - Method in class net.sf.ehcache.Cache
Returns a list of all element keys in the cache.
getKeysWithExpiryCheck() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns a list of all elements in the cache.
getKeysWithExpiryCheck() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns a list of all elements in the cache.
getKeysWithExpiryCheck() - Method in interface net.sf.ehcache.Ehcache
Returns a list of all elements in the cache.
getLastAccessTime() - Method in class net.sf.ehcache.DefaultElementEvictionData
Gets the last access time.
getLastAccessTime() - Method in class net.sf.ehcache.Element
Gets the last access time.
getLastAccessTime() - Method in interface net.sf.ehcache.ElementEvictionData
Gets the last access time.
getLastUpdateTime() - Method in class net.sf.ehcache.Element
If there is an Element in the Cache and it is replaced with a new Element for the same key, then both the version number and lastUpdateTime should be updated to reflect that.
getLatestOfCreationAndUpdateTime() - Method in class net.sf.ehcache.Element
Calculates the latest of creation and update time
getLeft() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Get this node's left child.
getLeft() - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Get this node's left child.
getLevel() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Get this node's level.
getLevel() - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Get this node's level.
getListenFor() - Method in class net.sf.ehcache.config.CacheConfiguration.CacheEventListenerFactoryConfiguration
Get the value mode in terms of the mode enum
getLiveCacheStatistics() - Method in class net.sf.ehcache.Cache
This is different from Ehcache.getStatistics() in the way that values returned from LiveCacheStatistics will reflect the current state of the cache (and not a snapshot of the cache when the api's were called like Ehcache.getStatistics())
getLiveCacheStatistics() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
This is different from Ehcache.getStatistics() in the way that values returned from LiveCacheStatistics will reflect the current state of the cache (and not a snapshot of the cache when the api's were called like Ehcache.getStatistics())
getLiveCacheStatistics() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
This is different from Ehcache.getStatistics() in the way that values returned from LiveCacheStatistics will reflect the current state of the cache (and not a snapshot of the cache when the api's were called like Ehcache.getStatistics())
getLiveCacheStatistics() - Method in interface net.sf.ehcache.Ehcache
This is different from Ehcache.getStatistics() in the way that values returned from LiveCacheStatistics will reflect the current state of the cache (and not a snapshot of the cache when the api's were called like Ehcache.getStatistics())
getLoadCount() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
getLoadCount
getLoadCount() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
getLoadCount
getLocalDiskSize() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of entries in the DiskStore
getLocalDiskSize() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of entries in the DiskStore
getLocalDiskSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of entries in the DiskStore
getLocalDiskSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of entries in the DiskStore
getLocalDiskSize() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of entries in the DiskStore
getLocalDiskSizeInBytes() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of of bytes used by entries in the DiskStore
getLocalDiskSizeInBytes() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of of bytes used by entries in the DiskStore
getLocalDiskSizeInBytes() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of of bytes used by entries in the DiskStore
getLocalDiskSizeInBytes() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Returns the usage of local disks in bytes
getLocalDiskSizeInBytes() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of of bytes used by entries in the DiskStore
getLocalHeapSize() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of entries in the MemoryStore
getLocalHeapSize() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of entries in the MemoryStore
getLocalHeapSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of entries in the MemoryStore
getLocalHeapSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of entries in the MemoryStore
getLocalHeapSize() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of entries in the MemoryStore
getLocalHeapSizeInBytes() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of of bytes used by entries in the MemoryStore
getLocalHeapSizeInBytes() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of of bytes used by entries in the MemoryStore
getLocalHeapSizeInBytes() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of of bytes used by entries in the MemoryStore
getLocalHeapSizeInBytes() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Returns the usage of local heap in bytes
getLocalHeapSizeInBytes() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of of bytes used by entries in the MemoryStore
getLocalKeyCache() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Check whether the local key cache is enabled
getLocalKeyCacheSize() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Get the size limit of the local key cache (if enabled)
getLocalKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns set of keys from the cache which are present in the node locally.
getLocalKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns set of keys from the cache which are present in the node locally.
getLocalKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns set of keys from the cache which are present in the node locally.
getLocalKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns set of keys from the cache which are present in the node locally.
getLocalKeys() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns set of keys from the cache which are present in the node locally.
getLocalKeys() - Method in interface net.sf.ehcache.store.TerracottaStore
Returns set of keys from the cache which are present in the node locally.
getLocalKeys() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Returns set of keys from the cache which are present in the node locally.
getLocalOffHeapSize() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of entries in the off-heap store
getLocalOffHeapSize() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of entries in the off-heap store
getLocalOffHeapSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of entries in the off-heap store
getLocalOffHeapSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of entries in the off-heap store
getLocalOffHeapSize() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of entries in the off-heap store
getLocalOffHeapSizeInBytes() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of of bytes used by entries in the off-heap store
getLocalOffHeapSizeInBytes() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of of bytes used by entries in the off-heap store
getLocalOffHeapSizeInBytes() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of of bytes used by entries in the off-heap store
getLocalOffHeapSizeInBytes() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Returns the usage of local off heap in bytes
getLocalOffHeapSizeInBytes() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of of bytes used by entries in the off-heap store
getLockFor(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Returns the ReadWriteLock guarding this key.
getLockForKey(Object) - Method in class net.sf.ehcache.Cache
Gets the lock for a given key
getLockForKey(Object) - Method in interface net.sf.ehcache.concurrent.StripedReadWriteLock
Returns a ReadWriteLock for a particular key
getLockForKey(Object) - Method in class net.sf.ehcache.concurrent.StripedReadWriteLockSync
Gets the RWL Stripe to use for a given key.
getLockForKey(Object) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Gets the Sync to use for a given key.
getLogging() - Method in class net.sf.ehcache.config.CacheConfiguration
Only used when cache is clustered with Terracotta
getLongBeanProperty(Object, String) - Static method in class net.sf.ehcache.hibernate.management.impl.BeanUtils
Retrieve a Long bean property value.
getMax() - Method in class net.sf.ehcache.search.expression.Between
Get the maximum value
getMaxBytesLocalDisk() - Method in class net.sf.ehcache.config.CacheConfiguration
The maximum amount of bytes the cache should occupy on disk
getMaxBytesLocalDisk() - Method in class net.sf.ehcache.config.Configuration
Maximum amount of bytes the CacheManager will use on the Disk Tier.
getMaxBytesLocalDisk() - Method in class net.sf.ehcache.management.CacheConfiguration
Maximum number of bytes that may be stored in the local disk store.
getMaxBytesLocalDisk() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Configured maximum number of bytes for the local disk store.
getMaxBytesLocalDisk() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxBytesLocalDisk() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Maximum number of bytes of entries in the disk stores of all caches that did not declare their own max size.
getMaxBytesLocalDisk() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Maximum number of bytes of entries in the disk stores of all caches that did not declare their own max size.
getMaxBytesLocalDisk() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMaxBytesLocalDiskAsString() - Method in class net.sf.ehcache.config.CacheConfiguration
The string form of the maximum amount of bytes the cache should occupy on disk
getMaxBytesLocalDiskAsString() - Method in class net.sf.ehcache.config.Configuration
 
getMaxBytesLocalDiskAsString() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxBytesLocalDiskAsString() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
getMaxBytesLocalDiskAsString() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getMaxBytesLocalDiskAsString() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMaxBytesLocalDiskPercentage() - Method in class net.sf.ehcache.config.CacheConfiguration
Getter for maximum bytes on disk expressed as a percentage
getMaxBytesLocalHeap() - Method in class net.sf.ehcache.config.CacheConfiguration
The maximum amount of bytes the cache should occupy on heap
getMaxBytesLocalHeap() - Method in class net.sf.ehcache.config.Configuration
Maximum amount of bytes the CacheManager will use on the heap
getMaxBytesLocalHeap() - Method in class net.sf.ehcache.management.CacheConfiguration
Maximum number of bytes that may be stored in local heap memory store.
getMaxBytesLocalHeap() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Configured maximum number of bytes for the local memory heap.
getMaxBytesLocalHeap() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxBytesLocalHeap() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Maximum number of bytes of entries in the heap memory stores of all caches that did not declare their own max size.
getMaxBytesLocalHeap() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Maximum number of bytes of entries in the heap memory stores of all caches that did not declare their own max size.
getMaxBytesLocalHeap() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMaxBytesLocalHeapAsString() - Method in class net.sf.ehcache.config.CacheConfiguration
The string form of the maximum amount of bytes the cache should occupy on heap
getMaxBytesLocalHeapAsString() - Method in class net.sf.ehcache.config.Configuration
 
getMaxBytesLocalHeapAsString() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxBytesLocalHeapAsString() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
getMaxBytesLocalHeapAsString() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getMaxBytesLocalHeapAsString() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMaxBytesLocalHeapPercentage() - Method in class net.sf.ehcache.config.CacheConfiguration
Getter for maximum bytes on heap expressed as a percentage
getMaxBytesLocalOffHeap() - Method in class net.sf.ehcache.config.CacheConfiguration
The maximum amount of bytes the cache should occupy off heap
getMaxBytesLocalOffHeap() - Method in class net.sf.ehcache.config.Configuration
Maximum amount of bytes the CacheManager will use on the OffHeap Tier.
getMaxBytesLocalOffHeap() - Method in class net.sf.ehcache.management.CacheConfiguration
Maximum number of bytes that may be stored in local off-heap memory store.
getMaxBytesLocalOffHeap() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Configured maximum number of bytes for the local off-heap memory.
getMaxBytesLocalOffHeap() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxBytesLocalOffHeap() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Maximum number of bytes of entries in the off-heap stores of all caches that did not declare their own max size.
getMaxBytesLocalOffHeap() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Maximum number of bytes of entries in the off-heap stores of all caches that did not declare their own max size.
getMaxBytesLocalOffHeap() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMaxBytesLocalOffHeapAsString() - Method in class net.sf.ehcache.config.CacheConfiguration
The string form of the maximum amount of bytes the cache should occupy off heap
getMaxBytesLocalOffHeapAsString() - Method in class net.sf.ehcache.config.Configuration
 
getMaxBytesLocalOffHeapAsString() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxBytesLocalOffHeapAsString() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
getMaxBytesLocalOffHeapAsString() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getMaxBytesLocalOffHeapAsString() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMaxBytesLocalOffHeapPercentage() - Method in class net.sf.ehcache.config.CacheConfiguration
Getter for maximum bytes off heap expressed as a percentage
getMaxDepth() - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Gets the maximum depth the SizeOf engine can normally traverse
getMaxDepthExceededBehavior() - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Gets the behavior of the SizeOf engine when the max depth is reached
getMaxElementsInMemory() - Method in class net.sf.ehcache.config.CacheConfiguration
Deprecated. use CacheConfiguration.getMaxEntriesLocalHeap()
getMaxElementsInMemory() - Method in class net.sf.ehcache.management.CacheConfiguration
Deprecated. use CacheConfiguration.getMaxEntriesLocalHeap()
getMaxElementsInMemory() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Deprecated. use CacheConfigurationMBean.getMaxEntriesLocalHeap()
getMaxElementsInMemory() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxElementsInMemory() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Deprecated. use SampledCacheMBean.getMaxEntriesLocalHeap() instead
getMaxElementsOnDisk() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getMaxElementsOnDisk() - Method in class net.sf.ehcache.management.CacheConfiguration
Deprecated. use CacheConfiguration.getMaxEntriesLocalDisk()
getMaxElementsOnDisk() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Deprecated. use CacheConfigurationMBean.getMaxEntriesLocalDisk()
getMaxElementsOnDisk() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxElementsOnDisk() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Deprecated. use SampledCacheMBean.getMaxEntriesLocalDisk() instead
getMaxEntriesLocalDisk() - Method in class net.sf.ehcache.config.CacheConfiguration
Configured maximum number of entries for the local disk store.
getMaxEntriesLocalDisk() - Method in class net.sf.ehcache.management.CacheConfiguration
Maximum number of entries that may be stored in the local disk store.
getMaxEntriesLocalDisk() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Configured maximum number of entries for the local disk store.
getMaxEntriesLocalDisk() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxEntriesLocalDisk() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMaxEntriesLocalHeap() - Method in class net.sf.ehcache.config.CacheConfiguration
Configured maximum number of entries for the local memory heap.
getMaxEntriesLocalHeap() - Method in class net.sf.ehcache.management.CacheConfiguration
Maximum number of entries that may be stored in local heap memory store.
getMaxEntriesLocalHeap() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Configured maximum number of entries for the local memory heap.
getMaxEntriesLocalHeap() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMaxEntriesLocalHeap() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMaxGetTimeMillis() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Return maximum time taken in milliseconds for a get operation
getMaxGetTimeMillis(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Return maximum time taken in milliseconds for a get operation for the input cache name
getMaxGetTimeMillis() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Return maximum time taken in milliseconds for a get operation
getMaxGetTimeMillis(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Return maximum time taken in milliseconds for a get operation for the input cache name
getMaxGetTimeMillis() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Return maximum time taken in milliseconds for a get operation
getMaxGetTimeMillis(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Return maximum time taken in milliseconds for a get operation for the input cache name
getMaxGetTimeMillis() - Method in class net.sf.ehcache.management.sampled.SampledCache
Return maximum time taken for a get operation in the cache in milliseconds
getMaxGetTimeMillis() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Return maximum time taken for a get operation in the cache in milliseconds
getMaxGetTimeMillis() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Return maximum time taken for a get operation in the cache in milliseconds
getMaxGetTimeMillis() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Return maximum time taken for a get operation in the cache in milliseconds
getMaxGetTimeMillis() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Return maximum time taken for a get operation in the cache in milliseconds
getMaximumChunkSizeBytes() - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Gets the maximum chunk size
getMaxMemoryOffHeap() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getMaxMemoryOffHeapInBytes() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getMaxMemoryOffHeapInBytes() - Method in class net.sf.ehcache.management.CacheConfiguration
Deprecated. use CacheConfiguration.getMaxBytesLocalOffHeap()
getMaxMemoryOffHeapInBytes() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Deprecated. use CacheConfigurationMBean.getMaxBytesLocalOffHeap()
getMaxSize() - Method in class net.sf.ehcache.pool.impl.AbstractPool
Return the maximum size of the pool.
getMaxSize() - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Return the maximum size of the pool.
getMaxSize() - Method in interface net.sf.ehcache.pool.Pool
Return the maximum size of the pool.
getMaxValue() - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
throws UnsupportedOperationException
getMaxWriteDelay() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Get the maximum number of seconds to wait before writing behind
getMBean() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.store.disk.DiskStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.store.DiskBackedMemoryStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.store.LruMemoryStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.store.MemoryOnlyStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.store.MemoryStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.store.NullStore
Optional implementation specific MBean exposed by the store.
getMBean() - Method in interface net.sf.ehcache.store.Store
Optional implementation specific MBean exposed by the store.
getMBean() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Optional implementation specific MBean exposed by the store.
getMBeanInfo() - Method in class net.sf.ehcache.management.Store
getMBeanRegisteredName() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Gets the name used to register this mbean.
getMBeanRegisteredName() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Gets the name used to register this mbean.
getMeasuredSize() - Method in exception net.sf.ehcache.pool.sizeof.MaxDepthExceededException
Get the partially measured size
getMemoryStore() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Returns the underlying memory store for this legacy wrapper.
getMemoryStoreEvictionPolicy() - Method in class net.sf.ehcache.Cache
 
getMemoryStoreEvictionPolicy() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getMemoryStoreEvictionPolicy() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
getMemoryStoreEvictionPolicy() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
getMemoryStoreEvictionPolicy() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getMemoryStoreEvictionPolicy() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getMemoryStoreObjectCount() - Method in class net.sf.ehcache.management.CacheStatistics
Gets the number of objects in the MemoryStore
getMemoryStoreObjectCount() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Gets the number of objects in the MemoryStore
getMemoryStoreObjectCount() - Method in class net.sf.ehcache.Statistics
 
getMemoryStoreSize() - Method in class net.sf.ehcache.Cache
Returns the number of elements in the memory store.
getMemoryStoreSize() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns the number of elements in the memory store.
getMemoryStoreSize() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns the number of elements in the memory store.
getMemoryStoreSize() - Method in interface net.sf.ehcache.Ehcache
Returns the number of elements in the memory store.
getMimeType() - Method in class net.sf.ehcache.MimeTypeByteArray
 
getMin() - Method in class net.sf.ehcache.search.expression.Between
Get the minimum value
getMinGetTimeMillis() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Return minimum time taken for a get operation in the cache in milliseconds
getMinGetTimeMillis(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Return minimum time taken in milliseconds for a get operation for the input cache name
getMinGetTimeMillis() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Return minimum time taken for a get operation in the cache in milliseconds
getMinGetTimeMillis(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Return minimum time taken in milliseconds for a get operation for the input cache name
getMinGetTimeMillis() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Return minimum time taken for a get operation in the cache in milliseconds
getMinGetTimeMillis(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Return minimum time taken in milliseconds for a get operation for the input cache name
getMinGetTimeMillis() - Method in class net.sf.ehcache.management.sampled.SampledCache
Return minimum time taken for a get operation in the cache in milliseconds
getMinGetTimeMillis() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Return minimum time taken for a get operation in the cache in milliseconds
getMinGetTimeMillis() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Return minimum time taken for a get operation in the cache in milliseconds
getMinGetTimeMillis() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Return minimum time taken for a get operation in the cache in milliseconds
getMinGetTimeMillis() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Return minimum time taken for a get operation in the cache in milliseconds
getMinimumObjectSize() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Minimal size an object will occupy on the heap in bytes.
getMinValue() - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
throws UnsupportedOperationException
getMinWriteDelay() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Get the minimum number of seconds to wait before writing behind
getMissCount() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getMonitoring() - Method in class net.sf.ehcache.config.Configuration
Get monitoring type, should not be null
getMostRecentSample() - Method in interface net.sf.ehcache.util.counter.sampled.SampledCounter
Returns the most recent sampled value
getMostRecentSample() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
Returns the most recent sampled value
getMultiRunner() - Method in class net.sf.ehcache.transaction.xa.processor.XAThreadPool
Reserve a thread from the pool
getName() - Method in class net.sf.ehcache.Cache
Gets the cache name.
getName() - Method in class net.sf.ehcache.CacheManager
Gets the name of the CacheManager.
getName() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getName() - Method in class net.sf.ehcache.config.Configuration
CacheManager name
getName() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
The name of the element
getName() - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Name of the attribute
getName() - Method in interface net.sf.ehcache.config.generator.model.NodeElement
The name of the element
getName() - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Name of the attribute
getName() - Method in class net.sf.ehcache.config.generator.model.SimpleNodeElement
The name of the element
getName() - Method in class net.sf.ehcache.config.SearchAttribute
Get the attribute name
getName() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets the cache name.
getName() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets the cache name.
getName() - Method in interface net.sf.ehcache.distribution.CachePeer
Gets the cache name.
getName() - Method in class net.sf.ehcache.distribution.RMICachePeer
Gets the cache name
getName() - Method in interface net.sf.ehcache.Ehcache
Gets the cache name.
getName() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
getName
getName() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
getName() - Method in interface net.sf.ehcache.loader.CacheLoader
Gets the name of a CacheLoader
getName() - Method in class net.sf.ehcache.management.Cache
Gets the cache name.
getName() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
getName() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
getName() - Method in class net.sf.ehcache.management.CacheManager
Gets the name of the CacheManager
getName() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Gets the name of the cache manager
getName() - Method in interface net.sf.ehcache.management.CacheMBean
Gets the cache name.
getName() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Gets the actual name of the cache manager.
getName() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Gets the actual name of the cache manager.
getName() - Method in class net.sf.ehcache.store.FifoPolicy
 
getName() - Method in class net.sf.ehcache.store.LfuPolicy
 
getName() - Method in class net.sf.ehcache.store.LruPolicy
 
getName() - Method in interface net.sf.ehcache.store.Policy
 
getName() - Method in class net.sf.ehcache.util.ProductInfo
 
getNewElement() - Method in class net.sf.ehcache.transaction.xa.commands.AbstractStoreCommand
Get the new element to put in the underlying store
getNextToLastAccessTime() - Method in class net.sf.ehcache.Element
Deprecated. The nextToLastAccessTime field is unused since version 1.7, retrieving it will return the lastAccessTime. Use #getLastAccessTime() instead.
getNodes() - Method in interface net.sf.ehcache.cluster.CacheCluster
Get all the nodes in the cluster
getNodes() - Method in class net.sf.ehcache.cluster.NoopCacheCluster
Get all the nodes in the cluster
getNodes() - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Get all the nodes in the cluster
getNonstopActiveDelegateHolder() - Method in class net.sf.ehcache.Cache
Returns the NonstopActiveDelegateHolder
getNonstopConfiguration() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Get the NonstopConfiguration, may be null
getNonstopExecutorService() - Method in class net.sf.ehcache.CacheManager
Return the NonstopExecutorService associated with this cacheManager
getNonstopExecutorService() - Method in interface net.sf.ehcache.constructs.nonstop.NonstopActiveDelegateHolder
Returns the current underlying NonstopExecutorService
getNonstopStore() - Method in interface net.sf.ehcache.constructs.nonstop.NonstopActiveDelegateHolder
Returns the nonstop store
getNonstopThreadStackTrace() - Method in class net.sf.ehcache.constructs.nonstop.NonstopThreadPool
Get the stack trace details of the nonstop thread for the current thread
getNonstopTimeoutBehaviorFactory() - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Get the NonstopTimeoutBehaviorFactory according to the active config
getNotificationInfo() - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
 
getNotificationInfo() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
 
getNotificationInfo() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
 
getNotificationInfo() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
 
getNotificationInfo() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
 
getNotificationInfo() - Method in class net.sf.ehcache.management.sampled.SampledCache
 
getNotificationInfo() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getNotifyListenersOnException() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Check whether listeners should be notified when an exception occurs on a writer operation
getNumberOfElementsInMemory(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns number of elements in-memory in the cache for the input region
getNumberOfElementsInMemory(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns number of elements in-memory in the cache for the input region
getNumberOfElementsInMemory(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns number of elements in-memory in the cache for the input region
getNumberOfElementsOffHeap(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns number of elements off-heap in the cache for the input region
getNumberOfElementsOffHeap(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns number of elements off-heap in the cache for the input region
getNumberOfElementsOffHeap(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns number of elements off-heap in the cache for the input region
getNumberOfElementsOnDisk(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns number of elements on-disk in the cache for the input region
getNumberOfElementsOnDisk(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns number of elements on-disk in the cache for the input region
getNumberOfElementsOnDisk(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns number of elements on-disk in the cache for the input region
getNumberOfThreads() - Method in class net.sf.ehcache.constructs.nonstop.util.CountingThreadFactory
Returns the number of threads this factory has created and currently alive
getObjectAlignment() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Object alignment / padding in bytes
getObjectCount() - Method in class net.sf.ehcache.management.CacheStatistics
Gets the number of elements stored in the cache.
getObjectCount() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Gets the number of elements stored in the cache.
getObjectCount() - Method in class net.sf.ehcache.Statistics
Gets the number of elements stored in the cache.
getObjectHeaderSize() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
The size of an object header in bytes.
getObjectKey() - Method in class net.sf.ehcache.Element
Gets the key attribute of the Element object.
getObjectKey() - Method in interface net.sf.ehcache.transaction.xa.commands.Command
Get the key of the element this command is working on
getObjectKey() - Method in class net.sf.ehcache.transaction.xa.commands.StorePutCommand
Get the key of the element this command is working on
getObjectKey() - Method in class net.sf.ehcache.transaction.xa.commands.StoreRemoveCommand
Get the key of the element this command is working on
getObjectName() - Method in class net.sf.ehcache.management.Store
 
getObjectValue() - Method in class net.sf.ehcache.Element
Gets the value attribute of the Element object as an Object.
getOffHeapHitCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of times a requested item was found in the off-heap store.
getOffHeapHitCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of times a requested item was found in the off-heap store.
getOffHeapHitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of times a requested item was found in the off-heap store.
getOffHeapHitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of times a requested item was found in the off-heap store.
getOffHeapHitCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of times a requested item was found in the off-heap store.
getOffHeapHitPercentage() - Method in class net.sf.ehcache.management.CacheStatistics
Returns the percentage of cache accesses that found a requested item cached off-heap.
getOffHeapHitPercentage() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Returns the percentage of cache accesses that found a requested item cached off-heap.
getOffHeapHits() - Method in class net.sf.ehcache.management.CacheStatistics
Number of times a requested item was found in the off-heap store.
getOffHeapHits() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Number of times a requested item was found in the off-heap store.
getOffHeapHits() - Method in class net.sf.ehcache.Statistics
Number of times a requested item was found in the off-heap store.
getOffHeapMissCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of times a requested item was not found in the off-heap store.
getOffHeapMissCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of times a requested item was not found in the off-heap store.
getOffHeapMissCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of times a requested item was not found in the off-heap store.
getOffHeapMissCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of times a requested item was not found in the off-heap store.
getOffHeapMissCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of times a requested item was not found in the off-heap store.
getOffHeapMisses() - Method in class net.sf.ehcache.management.CacheStatistics
getOffHeapMisses() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
 
getOffHeapMisses() - Method in class net.sf.ehcache.Statistics
Number of times a requested item was not found in the off-heap store.
getOffHeapSize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.management.sampled.SampledCache
Deprecated. use SampledCache.getLocalOffHeapSize()
getOffHeapSize() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Deprecated. use LiveCacheStatistics.getLocalOffHeapSize()
getOffHeapSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Deprecated. see LiveCacheStatisticsImpl.getLocalOffHeapSize()
getOffHeapSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Deprecated. see LiveCacheStatisticsWrapper.getLocalOffHeapSize()
getOffHeapSize() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Deprecated. see NullLiveCacheStatisticsData.getLocalOffHeapSize()
getOffHeapSize() - Method in class net.sf.ehcache.store.disk.DiskStore
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.store.LruMemoryStore
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.store.MemoryStore
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.store.NullStore
Returns the current local off-heap store size
getOffHeapSize() - Method in interface net.sf.ehcache.store.Store
Returns the current local off-heap store size
getOffHeapSize() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Returns the current local off-heap store size
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.store.disk.DiskStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.store.LruMemoryStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.store.MemoryStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.store.NullStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in interface net.sf.ehcache.store.Store
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapSizeInBytes() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Gets the size of the off-heap portion of the store, in bytes.
getOffHeapStoreObjectCount() - Method in class net.sf.ehcache.management.CacheStatistics
Gets the number of objects in the OffHeapStore
getOffHeapStoreObjectCount() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Gets the number of objects in the OffHeapStore
getOffHeapStoreObjectCount() - Method in class net.sf.ehcache.Statistics
 
getOffHeapStoreSize() - Method in class net.sf.ehcache.Cache
Returns the number of elements in the off-heap store.
getOffHeapStoreSize() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns the number of elements in the off-heap store.
getOffHeapStoreSize() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns the number of elements in the off-heap store.
getOffHeapStoreSize() - Method in interface net.sf.ehcache.Ehcache
Returns the number of elements in the off-heap store.
getOldElement() - Method in class net.sf.ehcache.transaction.xa.commands.AbstractStoreCommand
Get the element in the underlying store at the time this command is created
getOnDiskHitCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of times a requested item was found in the Disk Store.
getOnDiskHitCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of times a requested item was found in the Disk Store.
getOnDiskHitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of times a requested item was found in the Disk Store.
getOnDiskHitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of times a requested item was found in the Disk Store.
getOnDiskHitCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of times a requested item was found in the Disk Store.
getOnDiskHitPercentage() - Method in class net.sf.ehcache.management.CacheStatistics
Returns the percentage of cache accesses that found a requested item cached on disk.
getOnDiskHitPercentage() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Returns the percentage of cache accesses that found a requested item cached on disk.
getOnDiskHits() - Method in class net.sf.ehcache.management.CacheStatistics
Number of times a requested item was found in the Disk Store.
getOnDiskHits() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Number of times a requested item was found in the Disk Store.
getOnDiskHits() - Method in class net.sf.ehcache.Statistics
Number of times a requested item was found in the Disk Store.
getOnDiskMissCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of times a requested item was not found in the Disk Store.
getOnDiskMissCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of times a requested item was not found in the Disk Store.
getOnDiskMissCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of times a requested item was not found in the Disk Store.
getOnDiskMissCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of times a requested item was not found in the Disk Store.
getOnDiskMissCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of times a requested item was not found in the Disk Store.
getOnDiskMisses() - Method in class net.sf.ehcache.management.CacheStatistics
getOnDiskMisses() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
 
getOnDiskMisses() - Method in class net.sf.ehcache.Statistics
Number of times a requested item was not found in the Disk Store.
getOnDiskPool() - Method in class net.sf.ehcache.CacheManager
Return this cache manager's shared on-disk pool
getOnDiskSize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.management.sampled.SampledCache
Deprecated. use SampledCache.getLocalDiskSize()
getOnDiskSize() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Deprecated. use LiveCacheStatistics.getLocalDiskSize()
getOnDiskSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Deprecated. see LiveCacheStatisticsImpl.getLocalDiskSize()
getOnDiskSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Deprecated. see LiveCacheStatisticsWrapper.getLocalDiskSize()
getOnDiskSize() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Deprecated. see NullLiveCacheStatisticsData.getLocalDiskSize()
getOnDiskSize() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Return the number of on-disk elements
getOnDiskSize() - Method in class net.sf.ehcache.store.disk.DiskStore
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.store.LruMemoryStore
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.store.MemoryStore
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.store.NullStore
Returns the current local on-disk store size
getOnDiskSize() - Method in interface net.sf.ehcache.store.Store
Returns the current local on-disk store size
getOnDiskSize() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Returns the current local on-disk store size
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Return this size in bytes of this factory
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.store.disk.DiskStore
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.store.LruMemoryStore
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.store.MemoryStore
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.store.NullStore
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in interface net.sf.ehcache.store.Store
Gets the size of the on-disk portion of the store, in bytes.
getOnDiskSizeInBytes() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Gets the size of the on-disk portion of the store, in bytes.
getOnHeapPool() - Method in class net.sf.ehcache.CacheManager
Return this cache manager's shared on-heap pool
getOptimisticFailureCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns Optimistic failure count
getOptimisticFailureCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns Optimistic failure count
getOptimisticFailureCount() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
getOptimisticFailureCount
getOptimisticFailureCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns Optimistic failure count
getOptimisticFailureCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns Optimistic failure count
getOrCreateNonstopExecutorService(CacheManager) - Method in class net.sf.ehcache.constructs.nonstop.CacheManagerExecutorServiceFactory
Creates a NonstopExecutorService and returns it if not already created
getOrCreateNonstopExecutorService(CacheManager) - Method in interface net.sf.ehcache.constructs.nonstop.NonstopExecutorServiceFactory
Creates a NonstopExecutorService and returns it if not already created
getOrCreateSoftLockFactory(Ehcache) - Method in interface net.sf.ehcache.terracotta.ClusteredInstanceFactory
Create a SoftLockFactory for a cache
getOrCreateSoftLockFactory(Ehcache) - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Create a SoftLockFactory for a cache
getOrCreateTransactionIDFactory() - Method in class net.sf.ehcache.CacheManager
Get or create a TransactionIDFactory
getOrCreateXAResource() - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Get or create the XAResource of this XA store
getOrdering() - Method in interface net.sf.ehcache.store.StoreQuery
Get the requested search orderings
getOriginalConfigDeclaration() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Get the original cache configuration
getOriginalConfigDeclaration(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the original cache configuration for the supplied region
getOriginalConfigDeclaration() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Get the original cache configuration
getOriginalConfigDeclaration(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the original cache configuration for the supplied region
getOriginalConfigDeclaration() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Get the original cache configuration
getOriginalConfigDeclaration(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the original cache configuration for the supplied region
getOriginalConfigurationText() - Method in class net.sf.ehcache.CacheManager
Returns the original configuration text for this CacheManager
getOriginalConfigurationText(String) - Method in class net.sf.ehcache.CacheManager
Returns the original configuration text for the input cacheName
getOriginalEmbeddedConfig() - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Get the original embedded config
getOriginalPath() - Method in class net.sf.ehcache.config.DiskStoreConfiguration
 
getOrphanEviction() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Check whether orphan eviction is enabled
getOrphanEvictionPeriod() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Get the number of regular eviction cycles between orphan evictions
getParent() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Returns the parent of this element.
getParent() - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Returns the parent of this element.
getPatchLevel() - Method in class net.sf.ehcache.util.ProductInfo
 
getPath() - Method in class net.sf.ehcache.config.DiskStoreConfiguration
The diskStore path
getPayload() - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Return the 'value' object held within this node.
getPayload() - Method in class net.sf.ehcache.store.disk.ods.Region
Return the 'value' object held within this node.
getPinnedToStore() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getPinnedToStore() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getPinningConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getPointerSize() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Size of a pointer in bytes on this runtime
getPool() - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Return the pool this accessor is associated with.
getPoolableStores() - Method in class net.sf.ehcache.pool.impl.AbstractPool
Return the stores accessing this pool.
getPoolableStores() - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Return the stores accessing this pool.
getPoolableStores() - Method in interface net.sf.ehcache.pool.Pool
Return the stores accessing this pool.
getPrepareStatementCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns prepare statement count
getPrepareStatementCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns prepare statement count
getPrepareStatementCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns prepare statement count
getPrepareStatementCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns prepare statement count
getPresentPinnedKeys() - Method in class net.sf.ehcache.store.disk.DiskStore
Returns all the keys that are pinned, for which there is a mapping present
getPresentPinnedKeys() - Method in class net.sf.ehcache.store.MemoryStore
Returns all the keys that are pinned, for which there is a mapping present
getPresentPinnedKeys() - Method in class net.sf.ehcache.store.NullStore
Returns all the keys that are pinned, for which there is a mapping present
getPresentPinnedKeys() - Method in interface net.sf.ehcache.store.TierableStore
Returns all the keys that are pinned, for which there is a mapping present
getProperties() - Method in class net.sf.ehcache.config.FactoryConfiguration
Getter.
getProperties() - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Get the properties
getPropertySeparator() - Method in class net.sf.ehcache.config.FactoryConfiguration
Getter
getPropertySeparator() - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Get the property separator
getPutCount() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getPutCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of puts that has happened in the cache
getPutCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of puts that has happened in the cache
getPutCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of puts that has happened in the cache
getPutCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of puts that has happened in the cache
getPutCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of puts that has happened in the cache
getQuery() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
getQuery
getQueryCacheManagerObjectName(String, String) - Static method in class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
Returns an ObjectName that can be used for querying all Cache ObjectName's for the passed cacheManagerName
getQueryCacheManagersObjectName(String) - Static method in class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
Returns an ObjectName that can be used to query all objectNames of SampledEhcacheMBeans.SAMPLED_CACHE_MANAGER_TYPE
getQueryExecutionCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns the query execution count.
getQueryExecutionCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the query execution count.
getQueryExecutionCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns the query execution count.
getQueryExecutionCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns the query execution count.
getQueryExecutionRate() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns rate of HQL query executed in the DB
getQueryExecutionRate() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns rate of HQL query executed in the DB
getQueryExecutionRate() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns rate of HQL query executed in the DB
getQueryExecutionRate() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns rate of HQL query executed in the DB
getQueryExecutionSample() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns last count sample of HQL's getting executed in the DB.
getQueryExecutionSample() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns last count sample of HQL's getting executed in the DB.
getQueryExecutionSample() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns last count sample of HQL's getting executed in the DB.
getQueryExecutionSample() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns last count sample of HQL's getting executed in the DB.
getQueryStats() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns TabularData of query stats
getQueryStats() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns TabularData of query stats
getQueryStats() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns TabularData of query stats
getQueryStats() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns TabularData of query stats
getQueueSize() - Method in interface net.sf.ehcache.writer.writebehind.WriteBehind
Gets the best estimate for items in the queue still awaiting processing.
getQueueSize() - Method in class net.sf.ehcache.writer.writebehind.WriteBehindManager
Gets the best estimate for items in the queue still awaiting processing.
getQueueSize() - Method in class net.sf.ehcache.writer.writebehind.WriteBehindQueueManager
Gets the best estimate for items in the queue still awaiting processing.
getQuiet(Serializable) - Method in class net.sf.ehcache.Cache
Gets an element from the cache, without updating Element statistics.
getQuiet(Object) - Method in class net.sf.ehcache.Cache
Gets an element from the cache, without updating Element statistics.
getQuiet(Serializable) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets an element from the cache, without updating Element statistics.
getQuiet(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets an element from the cache, without updating Element statistics.
getQuiet(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets an element from the cache, without updating Element statistics.
getQuiet(Serializable) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets an element from the cache, without updating Element statistics.
getQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Gets an Element from the Store, without updating statistics
getQuiet(Serializable) - Method in interface net.sf.ehcache.distribution.CachePeer
Gets an element from the cache, without updating Element statistics.
getQuiet(Serializable) - Method in class net.sf.ehcache.distribution.RMICachePeer
Gets an element from the cache, without updating Element statistics.
getQuiet(Serializable) - Method in class net.sf.ehcache.distribution.TransactionalRMICachePeer
 
getQuiet(Serializable) - Method in interface net.sf.ehcache.Ehcache
Gets an element from the cache, without updating Element statistics.
getQuiet(Object) - Method in interface net.sf.ehcache.Ehcache
Gets an element from the cache, without updating Element statistics.
getQuiet(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.store.LruMemoryStore
Gets an item from the cache, without updating statistics.
getQuiet(Object) - Method in class net.sf.ehcache.store.MemoryStore
Gets an item from the cache, without updating statistics.
getQuiet(Object) - Method in class net.sf.ehcache.store.NullStore
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in interface net.sf.ehcache.store.Store
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Gets an Element from the Store, without updating statistics
getQuiet(Object) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Gets an Element from the Store, without updating statistics
getRandomSample(ElementSubstituteFilter, int, Object) - Method in class net.sf.ehcache.store.disk.DiskStore
Select a random sample of elements generated by the supplied factory.
getRandomValues(int, Object) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
getRate() - Method in class net.sf.ehcache.util.ratestatistics.AtomicRateStatistic
Return the rate of events per unit time.
getRate() - Method in interface net.sf.ehcache.util.ratestatistics.RateStatistic
Return the rate of events per unit time.
getRate() - Method in class net.sf.ehcache.util.ratestatistics.UnlockedRateStatistic
Return the rate of events per unit time.
getRateLimitPerSecond() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Get the maximum number of write operations to allow per second.
getReadWriteLock() - Method in class net.sf.ehcache.concurrent.ReadWriteLockSync
Gets the ReadWriteLock backing this sync.
getRecreateCount() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
getRecreateCount
getRegex() - Method in class net.sf.ehcache.search.expression.ILike
Return regex string.
getRegion() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getRegion() - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheCollectionRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheCollectionRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.strategy.ReadWriteEhcacheCollectionRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.strategy.ReadWriteEhcacheEntityRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheCollectionRegionAccessStrategy
getRegion() - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
getRegionCacheAttributes(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns a map containing attributes of the cache for the input cache region name
getRegionCacheAttributes() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns a map containing mapping of all cache region names to their attributes
getRegionCacheAttributes() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns a map containing mapping of all cache region names to their attributes
getRegionCacheAttributes(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns a map containing attributes of the cache for the input cache region name
getRegionCacheAttributes() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns a map containing mapping of all cache region names to their attributes
getRegionCacheAttributes(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns a map containing attributes of the cache for the input cache region name
getRegionCacheMaxTTISeconds(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the time to idle for the input cache region
getRegionCacheMaxTTISeconds(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the time to idle for the input cache region
getRegionCacheMaxTTISeconds(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the time to idle for the input cache region
getRegionCacheMaxTTLSeconds(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the time to live for the input cache region
getRegionCacheMaxTTLSeconds(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the time to live for the input cache region
getRegionCacheMaxTTLSeconds(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the time to live for the input cache region
getRegionCacheOrphanEvictionPeriod(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the orphan eviction period for the input cache region.
getRegionCacheOrphanEvictionPeriod(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the orphan eviction period for the input cache region.
getRegionCacheOrphanEvictionPeriod(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the orphan eviction period for the input cache region.
getRegionCacheSamples() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns a map containing mapping between cache names and an array containing hit, miss and put count samples
getRegionCacheSamples() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns a map containing mapping between cache names and an array containing hit, miss and put count samples
getRegionCacheSamples() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns a map containing mapping between cache names and an array containing hit, miss and put count samples
getRegionCacheTargetMaxInMemoryCount(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the maxElementsInMemory of the input cache region
getRegionCacheTargetMaxInMemoryCount(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the maxElementsInMemory of the input cache region
getRegionCacheTargetMaxInMemoryCount(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the maxElementsInMemory of the input cache region
getRegionCacheTargetMaxTotalCount(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the maxElementsOnDisk of the input cache region
getRegionCacheTargetMaxTotalCount(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the maxElementsOnDisk of the input cache region
getRegionCacheTargetMaxTotalCount(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the maxElementsOnDisk of the input cache region
getRegionName() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated.  
getRegisteredCacheExtensions() - Method in class net.sf.ehcache.Cache
 
getRegisteredCacheExtensions() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
getRegisteredCacheExtensions() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
getRegisteredCacheExtensions() - Method in interface net.sf.ehcache.Ehcache
 
getRegisteredCacheLoaders() - Method in class net.sf.ehcache.Cache
 
getRegisteredCacheLoaders() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
getRegisteredCacheLoaders() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
getRegisteredCacheLoaders() - Method in interface net.sf.ehcache.Ehcache
 
getRegisteredCacheWriter() - Method in class net.sf.ehcache.Cache
Retrieves the CacheWriter that was registered for this cache.
getRegisteredCacheWriter() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Retrieves the CacheWriter that was registered for this cache.
getRegisteredCacheWriter() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Retrieves the CacheWriter that was registered for this cache.
getRegisteredCacheWriter() - Method in interface net.sf.ehcache.Ehcache
Retrieves the CacheWriter that was registered for this cache.
getRegisteredListeners() - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Gets a Set of the listeners registered to this class
getRemoveCount() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
getRemoveCount
getRemovedCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of elements removed since creation or last clear
getRemovedCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of elements removed since creation or last clear
getRemovedCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of elements removed since creation or last clear
getRemovedCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of elements removed since creation or last clear
getRemovedCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of elements removed since creation or last clear
getRemovedKeys() - Method in class net.sf.ehcache.transaction.xa.XATransactionContext
getter to all keys pending deletion from the store
getRequestType() - Method in class net.sf.ehcache.transaction.xa.processor.XARequest
 
getRequiredCoreVersion() - Method in class net.sf.ehcache.util.ProductInfo
 
getRetryAttemptDelaySeconds() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Retrieves the number of seconds to wait before retrying an failed operation.
getRetryAttempts() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Retrieves the number of times the write of element is retried.
getRight() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Get this node's right child.
getRight() - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Get this node's right child.
getRoleName() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
getRoleName
getRoot() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
Returns the root node of this tree.
getSampledCacheStatistics() - Method in class net.sf.ehcache.Cache
Returns sampled statistics for this cache.
getSampledCacheStatistics() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns sampled statistics for this cache.
getSampledCacheStatistics() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns sampled statistics for this cache.
getSampledCacheStatistics() - Method in interface net.sf.ehcache.Ehcache
Returns sampled statistics for this cache.
getScheme() - Method in interface net.sf.ehcache.cluster.CacheCluster
Get scheme name for this cluster info.
getScheme() - Method in class net.sf.ehcache.cluster.NoopCacheCluster
Always returns the ClusterScheme.NONE
getScheme() - Method in interface net.sf.ehcache.distribution.CacheManagerPeerListener
The replication scheme this listener interacts with.
getScheme() - Method in interface net.sf.ehcache.distribution.CacheManagerPeerProvider
The replication scheme.
getScheme() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
The replication scheme this listener interacts with.
getScheme() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
The replication scheme.
getScheme() - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Get scheme name for this cluster info.
getSearchable() - Method in class net.sf.ehcache.config.CacheConfiguration
Get the search configuration for this cache (if any)
getSearchable() - Method in class net.sf.ehcache.management.sampled.SampledCache
Is the cache configured for search
getSearchable() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
getSearchable() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getSearchable() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Is the cache configured for search
getSearchAttribute(String) - Method in class net.sf.ehcache.Cache
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Retrieve the given named search attribute
getSearchAttribute(String) - Method in interface net.sf.ehcache.Ehcache
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.store.AbstractStore
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.store.MemoryOnlyStore
Retrieve the given named search attribute
getSearchAttribute(String) - Method in interface net.sf.ehcache.store.Store
Retrieve the given named search attribute
getSearchAttribute(String) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Retrieve the given named search attribute
getSearchAttributes() - Method in class net.sf.ehcache.config.CacheConfiguration
Get the defined search attributes indexed by attribute name
getSearchAttributes() - Method in class net.sf.ehcache.config.Searchable
Get the defined search attributes indexed by attribute name
getSearchesPerSecond() - Method in class net.sf.ehcache.Cache
Get the number of search executions that have completed in the last second
getSearchesPerSecond() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Get the number of search executions that have completed in the last second
getSearchesPerSecond() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Get the number of search executions that have completed in the last second
getSearchesPerSecond() - Method in interface net.sf.ehcache.Ehcache
Get the number of search executions that have completed in the last second
getSearchesPerSecond() - Method in class net.sf.ehcache.management.sampled.SampledCache
Get the number of searches that have finished execution in the last second
getSearchesPerSecond() - Method in class net.sf.ehcache.Statistics
Get the number of search executions that have completed in the last second
getSearchesPerSecond() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get the number of searches that have finished execution in the last second
getSearchesPerSecond() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get the number of searches that have finished execution in the last second
getSearchesPerSecond() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get the number of searches that have finished execution in the last second
getSearchesPerSecond() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get the number of searches that have finished execution in the last second
getSerializableKey() - Method in class net.sf.ehcache.distribution.EventMessage
 
getSerializedSize() - Method in class net.sf.ehcache.Element
The size of this object in serialized form.
getSessionCloseCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns session close count
getSessionCloseCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns session close count
getSessionCloseCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns session close count
getSessionCloseCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns session close count
getSessionOpenCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns session open count
getSessionOpenCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns session open count
getSessionOpenCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns session open count
getSessionOpenCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns session open count
getSettings() - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Return the hibernate settings
getShortName() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
getShortName() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
getShortName
getShortName() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
getShortName
getSize() - Method in class net.sf.ehcache.Cache
Gets the size of the cache.
getSize() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets the size of the cache.
getSize() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets the size of the cache.
getSize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns the current local store size
getSize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns the current local store size
getSize() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns the current local store size
getSize() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns the current local store size
getSize() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns the current local store size
getSize() - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Returns the current local store size
getSize() - Method in interface net.sf.ehcache.Ehcache
Gets the size of the cache.
getSize() - Method in class net.sf.ehcache.management.sampled.SampledCache
Size of the cache based on current accuracy settings.
getSize() - Method in class net.sf.ehcache.pool.impl.AbstractPool
Return the used size of the pool.
getSize() - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Return the used size of the pool.
getSize() - Method in interface net.sf.ehcache.pool.Pool
Return the used size of the pool.
getSize() - Method in interface net.sf.ehcache.pool.PoolAccessor
Return how many bytes this accessor consumes from the pool.
getSize() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Size of the cache based on current accuracy settings.
getSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Size of the cache based on current accuracy settings.
getSize() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Size of the cache based on current accuracy settings.
getSize() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Size of the cache based on current accuracy settings.
getSize() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory.DiskMarker
Returns the size of the currently occupying element.
getSize() - Method in class net.sf.ehcache.store.disk.DiskStore
Returns the current local store size
getSize() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Returns the current local store size
getSize() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Returns the current local store size
getSize() - Method in class net.sf.ehcache.store.LruMemoryStore
Returns the current cache size.
getSize() - Method in class net.sf.ehcache.store.MemoryStore
Returns the current store size.
getSize() - Method in class net.sf.ehcache.store.NullStore
Returns the current local store size
getSize() - Method in interface net.sf.ehcache.store.Store
Returns the current local store size
getSize() - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Returns the current local store size
getSize() - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Returns the current local store size
getSize() - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Returns the current local store size
getSizeBasedOnAccuracy(int) - Method in class net.sf.ehcache.Cache
Accurately measuring statistics can be expensive.
getSizeBasedOnAccuracy(int) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Accurately measuring statistics can be expensive.
getSizeBasedOnAccuracy(int) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Accurately measuring statistics can be expensive.
getSizeBasedOnAccuracy(int) - Method in interface net.sf.ehcache.Ehcache
Accurately measuring statistics can be expensive.
getSizeInBytes(PoolableStore) - Method in class net.sf.ehcache.pool.impl.AbstractFromLargestCachePoolEvictor
Get a store size in bytes for a chosen resource
getSizeInBytes(PoolableStore) - Method in class net.sf.ehcache.pool.impl.FromLargestCacheOnDiskPoolEvictor
Get a store size in bytes for a chosen resource
getSizeInBytes(PoolableStore) - Method in class net.sf.ehcache.pool.impl.FromLargestCacheOnHeapPoolEvictor
Get a store size in bytes for a chosen resource
getSizeInBytes() - Method in class net.sf.ehcache.store.LruMemoryStore
Measures the size of the memory store by using the sizeof engine.
getSizeInMemory() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Warning: This method can be very expensive to run.
getSizeInMemory() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
getSizeModifier() - Method in class net.sf.ehcache.transaction.xa.XATransactionContext
The underlying store's size modifier.
getSizeOfPolicyConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getSizeOfPolicyConfiguration() - Method in class net.sf.ehcache.config.Configuration
Gets the SizeOf policy configuration.
getSoftLockFactory(String) - Method in class net.sf.ehcache.CacheManager
Get the SoftLockFactory of a cache
getSoftLocksForCache(String) - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Get all soft locks registered in this context for a specific cache
getStaleTime() - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
The time after which an unrefreshed peer provider entry is considered stale.
getStandardClassLoader() - Static method in class net.sf.ehcache.util.ClassLoaderUtil
Gets the ClassLoader that all classes in ehcache, and extensions, should use for classloading.
getStatistics() - Method in class net.sf.ehcache.Cache
Gets an immutable Statistics object representing the Cache statistics at the time.
getStatistics() - Method in class net.sf.ehcache.config.CacheConfiguration
Gets whether the cache's statistics will be enabled at startup
getStatistics() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets an immutable Statistics object representing the Cache statistics at the time.
getStatistics() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets an immutable Statistics object representing the Cache statistics at the time.
getStatistics() - Method in interface net.sf.ehcache.Ehcache
Gets an immutable Statistics object representing the Cache statistics at the time.
getStatistics() - Method in class net.sf.ehcache.management.Cache
Gets the JMX cache statistics
getStatistics() - Method in interface net.sf.ehcache.management.CacheMBean
Gets the JMX cache statistics
getStatisticsAccuracy() - Method in class net.sf.ehcache.Cache
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in interface net.sf.ehcache.Ehcache
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.management.CacheStatistics
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.management.sampled.SampledCache
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.Statistics
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Accurately measuring statistics can be expensive.
getStatisticsAccuracy() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get value for statisticsAccuracy
getStatisticsAccuracy() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get value for statisticsAccuracy
getStatisticsAccuracy() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get value for statisticsAccuracy
getStatisticsAccuracy() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get value for statisticsAccuracy
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.management.CacheStatistics
Accurately measuring statistics can be expensive.
getStatisticsAccuracyDescription() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Accurately measuring statistics can be expensive.
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.management.sampled.SampledCache
Accurately measuring statistics can be expensive.
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.Statistics
Accurately measuring statistics can be expensive.
getStatisticsAccuracyDescription() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Accurately measuring statistics can be expensive.
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Accurately measuring statistics can be expensive.
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Accurately measuring statistics can be expensive.
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Accurately measuring statistics can be expensive.
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Get Description for statisticsAccuracy
getStatisticsAccuracyDescription() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Get Description for statisticsAccuracy
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Get Description for statisticsAccuracy
getStatisticsAccuracyDescription() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Get Description for statisticsAccuracy
getStatus() - Method in class net.sf.ehcache.Cache
Gets the status attribute of the Cache.
getStatus() - Method in class net.sf.ehcache.CacheManager
Gets the status attribute of the Ehcache
getStatus() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Gets the status attribute of the Cache.
getStatus() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Gets the status attribute of the Cache.
getStatus() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Returns the listener status.
getStatus() - Method in interface net.sf.ehcache.Ehcache
Gets the status attribute of the Cache.
getStatus() - Method in interface net.sf.ehcache.event.CacheManagerEventListener
Returns the listener status.
getStatus() - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Returns the listener status.
getStatus() - Method in interface net.sf.ehcache.extension.CacheExtension
 
getStatus() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistrationImpl
Returns the listener status.
getStatus() - Method in interface net.sf.ehcache.loader.CacheLoader
 
getStatus() - Method in class net.sf.ehcache.management.Cache
Gets the status attribute of the Cache.
getStatus() - Method in class net.sf.ehcache.management.CacheManager
Gets the status attribute of the Ehcache
getStatus() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Gets the status attribute of the Ehcache
getStatus() - Method in interface net.sf.ehcache.management.CacheMBean
Gets the status attribute of the Cache.
getStatus() - Method in class net.sf.ehcache.management.ManagementService
Returns the listener status.
getStatus() - Method in class net.sf.ehcache.management.sampled.SampledCache
Gets the status attribute of the Cache.
getStatus() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Gets the status attribute of the Ehcache
getStatus() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Gets the status attribute of the Ehcache
getStatus() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Gets the status attribute of the Cache.
getStatus() - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Returns the listener status.
getStatus() - Method in class net.sf.ehcache.store.disk.DiskStore
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.store.LruMemoryStore
Gets the status of the MemoryStore.
getStatus() - Method in class net.sf.ehcache.store.MemoryStore
Gets the status of the MemoryStore.
getStatus() - Method in class net.sf.ehcache.store.NullStore
Returns the cache status.
getStatus() - Method in interface net.sf.ehcache.store.Store
Returns the cache status.
getStatus() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Returns the cache status.
getStorageStrategy() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Get the value mode in terms of the mode enum
getStore() - Method in class net.sf.ehcache.CacheStoreHelper
Returns the internal Store of the cache
getStore() - Method in class net.sf.ehcache.config.PinningConfiguration
Return the lowest store from which elements must not be evicted from
getStore() - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Return the store that uses this accessor
getStore() - Method in interface net.sf.ehcache.pool.PoolAccessor
Return the store that uses this accessor
getStoreMBean() - Method in class net.sf.ehcache.Cache
Get the optional store management bean for this cache.
getSubmitAttemptCount() - Method in exception net.sf.ehcache.constructs.nonstop.TaskNotSubmittedTimeoutException
Getter for submit attempts made.
getSuccessfulTransactionCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns successful transaction count
getSuccessfulTransactionCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns successful transaction count
getSuccessfulTransactionCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns successful transaction count
getSuccessfulTransactionCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns successful transaction count
getSyncForKey(Object) - Method in interface net.sf.ehcache.concurrent.CacheLockProvider
Gets the Sync Stripe to use for a given key.
getSyncForKey(Object) - Method in class net.sf.ehcache.concurrent.StripedReadWriteLockSync
Gets the Sync Stripe to use for a given key.
getSyncForKey(Object) - Method in class net.sf.ehcache.constructs.nonstop.concurrency.NonstopCacheLockProvider
Gets the Sync Stripe to use for a given key.
getTerracottaClusteredSize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.store.disk.DiskStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.store.LruMemoryStore
Returns nothing since a disk store isn't clustered
getTerracottaClusteredSize() - Method in class net.sf.ehcache.store.MemoryStore
Returns nothing since a disk store isn't clustered
getTerracottaClusteredSize() - Method in class net.sf.ehcache.store.NullStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in interface net.sf.ehcache.store.Store
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Returns the current Terracotta clustered store size
getTerracottaClusteredSize() - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Returns the current Terracotta clustered store size
getTerracottaConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getTerracottaConfiguration() - Method in class net.sf.ehcache.config.Configuration
Gets the TerracottaClientConfiguration
getTerracottaConsistency() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getTerracottaConsistency() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
getTerracottaConsistency() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
getTerracottaConsistency() - Method in class net.sf.ehcache.management.sampled.SampledCache
Returns a textual description of a Terracotta-clustered cache's consistency mode.
getTerracottaConsistency() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Returns a textual description of a Terracotta-clustered cache's consistency mode.
getTerracottaDefaultStrategyForCurrentRuntime(CacheConfiguration) - Static method in class net.sf.ehcache.terracotta.TerracottaClient
Returns the default TerracottaConfiguration.StorageStrategy type for the current Terracotta runtime.
getTerracottaHibernateCacheRegionNames() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns the region names which are clustered with terracotta
getTerracottaHibernateCacheRegionNames() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns the region names which are clustered with terracotta
getTerracottaHibernateCacheRegionNames() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns the region names which are clustered with terracotta
getTerracottaStorageStrategy() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getTerracottaStorageStrategy() - Method in class net.sf.ehcache.management.sampled.SampledCache
Returns a textual description of a Terracotta-clustered cache's storage-strategy.
getTerracottaStorageStrategy() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Returns a textual description of a Terracotta-clustered cache's storage-strategy.
getTimeForClusterToForm() - Method in interface net.sf.ehcache.distribution.CacheManagerPeerProvider
Time for a cluster to form.
getTimeForClusterToForm() - Method in class net.sf.ehcache.distribution.ManualRMICacheManagerPeerProvider
Time for a cluster to form.
getTimeForClusterToForm() - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
Time for a cluster to form.
getTimeout() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Returns the lock timeout for this cache, which is 60s
getTimeout() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
getTimeoutBehavior() - Method in class net.sf.ehcache.config.NonstopConfiguration
Returns value of timeoutBehavior configured
getTimeoutBehaviorFactory(Properties) - Method in enum net.sf.ehcache.config.TimeoutBehaviorConfiguration.TimeoutBehaviorType
Get the NonstopTimeoutBehaviorFactory for this type
getTimeoutBehaviorType() - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Returns the type of timeout behavior configured
getTimeoutBehaviorTypeFromName(String) - Static method in enum net.sf.ehcache.config.TimeoutBehaviorConfiguration.TimeoutBehaviorType
Get the TimeoutBehaviorConfiguration.TimeoutBehaviorType corresponding to a name
getTimeoutMillis() - Method in class net.sf.ehcache.config.NonstopConfiguration
Returns the value of timeout in milliseconds
getTimeoutMillis() - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Gets the time to wait to acquire a lock.
getTimer() - Method in class net.sf.ehcache.CacheManager
Returns a FailSafeTimer associated with this CacheManager
getTimerTask() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
Returns the timer task for this sampled counter
getTimestamp() - Method in class net.sf.ehcache.util.counter.sampled.TimeStampedCounterValue
Get value of the timestamp
getTimeToIdle() - Method in class net.sf.ehcache.Element
 
getTimeToIdleSeconds() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getTimeToIdleSeconds() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
getTimeToIdleSeconds() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
getTimeToIdleSeconds() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getTimeToIdleSeconds() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getTimeToLive() - Method in class net.sf.ehcache.distribution.MulticastKeepaliveHeartbeatSender
 
getTimeToLive() - Method in class net.sf.ehcache.Element
 
getTimeToLiveSeconds() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
getTimeToLiveSeconds() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
getTimeToLiveSeconds() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
getTimeToLiveSeconds() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
getTimeToLiveSeconds() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
getTopology() - Method in interface net.sf.ehcache.terracotta.ClusteredInstanceFactory
Get an api for looking at the clustered node topology.
getTopology() - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Get an api for looking at the clustered node topology.
getTopologyListeners() - Method in interface net.sf.ehcache.cluster.CacheCluster
Get all the topology listeners
getTopologyListeners() - Method in class net.sf.ehcache.cluster.NoopCacheCluster
Get all the topology listeners
getTopologyListeners() - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Get all the topology listeners
getTransactional() - Method in class net.sf.ehcache.management.sampled.SampledCache
Is the cache a transactional one
getTransactional() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Are any of the caches transactional
getTransactional() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Are any of the caches transactional
getTransactional() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Is the cache a transactional one
getTransactionalMode() - Method in class net.sf.ehcache.config.CacheConfiguration
To what transactionalMode was the Cache set
getTransactionalMode() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Get the transactional mode of this store.
getTransactionalMode() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Get the transactional mode of this store.
getTransactionalMode() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Get the transactional mode of this store.
getTransactionalMode() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Get the transactional mode of this store.
getTransactionalMode() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Get the transactional mode of this store.
getTransactionalMode() - Method in interface net.sf.ehcache.store.TerracottaStore
Get the transactional mode of this store.
getTransactionalMode() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Get the transactional mode of this store.
getTransactionCommitRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getTransactionCommitRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
getTransactionCommitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getTransactionCommitRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getTransactionCommittedCount() - Method in class net.sf.ehcache.management.CacheManager
Get the committed transactions count
getTransactionCommittedCount() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Get the committed transactions count
getTransactionCommittedCount() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Get the committed transactions count
getTransactionCommittedCount() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Get the committed transactions count
getTransactionCommittedCount() - Method in class net.sf.ehcache.TransactionController
Get the committed transactions count
getTransactionController() - Method in class net.sf.ehcache.CacheManager
Get the TransactionController
getTransactionCount() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns transaction count
getTransactionCount() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns transaction count
getTransactionCount() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns transaction count
getTransactionCount() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns transaction count
getTransactionId() - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Get the transaction ID of the context
getTransactionID() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Get the ID of the transaction under which this soft lock is operating
getTransactionID() - Method in interface net.sf.ehcache.transaction.SoftLock
Get the ID of the transaction under which this soft lock is operating
getTransactionIdentifier(Transaction) - Method in class net.sf.ehcache.hibernate.EhcacheJtaTransactionManagerLookup
getTransactionManager(Properties) - Method in class net.sf.ehcache.hibernate.EhcacheJtaTransactionManagerLookup
getTransactionManager() - Method in class net.sf.ehcache.transaction.manager.DefaultTransactionManagerLookup
Lookup available txnManagers
getTransactionManager() - Method in interface net.sf.ehcache.transaction.manager.TransactionManagerLookup
Lookup available txnManagers
getTransactionManagerLookup() - Method in class net.sf.ehcache.Cache
Get the TransactionManagerLookup implementation used to lookup the TransactionManager.
getTransactionManagerLookup() - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
 
getTransactionManagerLookupConfiguration() - Method in class net.sf.ehcache.config.Configuration
Gets the transaction manager lookup configuration.
getTransactionRollbackRate() - Method in class net.sf.ehcache.management.sampled.SampledCache
getTransactionRollbackRate() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
getTransactionRollbackRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
getTransactionRollbackRate() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
 
getTransactionRolledBackCount() - Method in class net.sf.ehcache.management.CacheManager
Get the rolled back transactions count
getTransactionRolledBackCount() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Get the rolled back transactions count
getTransactionRolledBackCount() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Get the rolled back transactions count
getTransactionRolledBackCount() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Get the rolled back transactions count
getTransactionRolledBackCount() - Method in class net.sf.ehcache.TransactionController
Get the rolled back transactions count
getTransactionTimedOutCount() - Method in class net.sf.ehcache.management.CacheManager
Get the timed out transactions count.
getTransactionTimedOutCount() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Get the timed out transactions count.
getTransactionTimedOutCount() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Get the timed out transactions count.
getTransactionTimedOutCount() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Get the timed out transactions count.
getTransactionTimedOutCount() - Method in class net.sf.ehcache.TransactionController
Get the timed out transactions count.
getTransactionTimeout() - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
getType() - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Returns the type of timeout behavior configured
getType() - Method in class net.sf.ehcache.distribution.RmiEventMessage
Gets the event.
getType() - Method in class net.sf.ehcache.search.expression.ComparableValue
Attribute type.
getType() - Method in class net.sf.ehcache.search.expression.EqualTo
Get attribute type.
getType() - Method in class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Returns a stable identifier for the type this operation can be classified in.
getType() - Method in interface net.sf.ehcache.writer.writebehind.operations.SingleOperation
Returns a stable identifier for the type this operation can be classified in.
getType() - Method in class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Returns a stable identifier for the type this operation can be classified in.
getTypeName() - Method in enum net.sf.ehcache.config.TimeoutBehaviorConfiguration.TimeoutBehaviorType
Returns a String signifying this type
getUnavailableClusterScheme() - Method in exception net.sf.ehcache.cluster.ClusterSchemeNotAvailableException
Return the unavailable ClusterScheme this instance is associated with
getUnderlyingCacheLockProvider() - Method in interface net.sf.ehcache.constructs.nonstop.NonstopActiveDelegateHolder
Returns the current underlying CacheLockProvider
getUnderlyingTerracottaStore() - Method in interface net.sf.ehcache.constructs.nonstop.NonstopActiveDelegateHolder
Returns the current underlying TerracottaStore
getUniqueResourceIdentifier() - Method in interface net.sf.ehcache.distribution.CacheManagerPeerListener
A listener will normally have a resource that only one instance can use at the same time, such as a port.
getUniqueResourceIdentifier() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
A listener will normally have a resource that only one instance can use at the same time, such as a port.
getUnit() - Method in enum net.sf.ehcache.config.MemoryUnit
Retrieves the unit character for the MemoryUnit
getUpdateCheck() - Method in class net.sf.ehcache.config.Configuration
Get flag for updateCheck
getUpdateCount() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
getUpdateCount
getUpdateCount() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
getUpdateCount
getUpdateCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Number of updates that as happened in the cache
getUpdateCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Number of updates that as happened in the cache
getUpdateCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Number of updates that as happened in the cache
getUpdateCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Number of updates that as happened in the cache
getUpdateCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Number of updates that as happened in the cache
getUrl() - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Get url string
getUrl() - Method in interface net.sf.ehcache.distribution.CachePeer
The URL for the remote replicator to connect.
getUrl() - Method in class net.sf.ehcache.distribution.RMICachePeer
The URL for the remote replicator to connect.
getUrlBase() - Method in interface net.sf.ehcache.distribution.CachePeer
The URL base for the remote replicator to connect.
getUrlBase() - Method in class net.sf.ehcache.distribution.RMICachePeer
The URL base for the remote replicator to connect.
getUserDefinedSearchAttributes() - Method in class net.sf.ehcache.config.Searchable
Get the defined search attributes indexed by attribute name *excluding* any search attributes that are automatically/implicitly defined (eg.
getUserTransactionName() - Method in class net.sf.ehcache.hibernate.EhcacheJtaTransactionManagerLookup
getUUID() - Method in interface net.sf.ehcache.terracotta.ClusteredInstanceFactory
Returns a universally unique identifiers for this factory.
getUUID() - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Returns a universally unique identifiers for this factory.
getValue() - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Value of the attribute
getValue() - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Value of the attribute
getValue() - Method in class net.sf.ehcache.Element
Gets the value attribute of the Element object.
getValue() - Method in class net.sf.ehcache.MimeTypeByteArray
 
getValue() - Method in class net.sf.ehcache.search.expression.EqualTo
Get attribute value.
getValue() - Method in class net.sf.ehcache.search.impl.BaseResult
Return the value for this cache entry.
getValue() - Method in interface net.sf.ehcache.search.Result
Return the value for this cache entry.
getValue() - Method in interface net.sf.ehcache.util.counter.Counter
Gets current value of the counter
getValue() - Method in class net.sf.ehcache.util.counter.CounterImpl
Gets current value of the counter
getValue() - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
Gets current value of the counter
getValueMode() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Get the value mode in terms of the mode enum
getVersion() - Method in class net.sf.ehcache.Element
Gets the version attribute of the ElementAttributes object.
getVersion() - Method in class net.sf.ehcache.util.ProductInfo
 
getWithLoader(Object, CacheLoader, Object) - Method in class net.sf.ehcache.Cache
This method will return, from the cache, the Element associated with the argument "key".
getWithLoader(Object, CacheLoader, Object) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
This method is not appropriate to use with BlockingCache.
getWithLoader(Object, CacheLoader, Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
This method will return, from the cache, the object associated with the argument "key".
getWithLoader(Object, CacheLoader, Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
This method will return, from the cache, the object associated with the argument "key".
getWithLoader(Object, CacheLoader, Object) - Method in interface net.sf.ehcache.Ehcache
This method will return, from the cache, the object associated with the argument "key".
getWriteBatching() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Check whether write operations should be batched
getWriteBatchSize() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Retrieves the size of the batch operation.
getWriteBehindConcurrency() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Accessor
getWriteBehindMaxQueueSize() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Accessor
getWriteCoalescing() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
getWriteMode() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Get the write mode in terms of the mode enum
getWriterConcurrency() - Method in class net.sf.ehcache.management.sampled.SampledCache
Returns the number of configured write-behind queues/threads.
getWriterConcurrency() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Returns the number of configured write-behind queues/threads.
getWriterManager() - Method in class net.sf.ehcache.Cache
Obtain the writer manager that's used by this cache instance.
getWriterManager() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Obtain the writer manager that's used by this cache instance.
getWriterManager() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Obtain the writer manager that's used by this cache instance.
getWriterManager() - Method in interface net.sf.ehcache.Ehcache
Obtain the writer manager that's used by this cache instance.
getWriterMaxQueueSize() - Method in class net.sf.ehcache.management.CacheStatistics
Gets the maximum size of the write-behind queue, if any.
getWriterMaxQueueSize() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Gets the maximum size of the write-behind queue, if any.
getWriterMaxQueueSize() - Method in class net.sf.ehcache.management.sampled.SampledCache
Returns the maximum size of any write-behind queues.
getWriterMaxQueueSize() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Maximum elements that can be queued for processing by the write-behind writer
getWriterMaxQueueSize() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Maximum elements that can be queued for processing by the write-behind writer
getWriterMaxQueueSize() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Returns the maximum size of any write-behind queues.
getWriterQueueLength() - Method in class net.sf.ehcache.management.CacheStatistics
Gets the size of the write-behind queue, if any.
getWriterQueueLength() - Method in interface net.sf.ehcache.management.CacheStatisticsMBean
Gets the size of the write-behind queue, if any.
getWriterQueueLength() - Method in class net.sf.ehcache.management.sampled.SampledCache
Returns the total length of all write-behind queues for this cache
getWriterQueueLength() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
 
getWriterQueueLength() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Returns the total length of all write-behind queues across all caches
getWriterQueueLength() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Returns the total length of all write-behind queues for this cache
getWriterQueueLength() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Gets the size of the write-behind queue, if any.
getWriterQueueLength() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Gets the size of the write-behind queue, if any.
getWriterQueueLength() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Gets the size of the write-behind queue, if any.
getWriterQueueLength() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Gets the size of the write-behind queue, if any.
getWriterQueueSize() - Method in class net.sf.ehcache.Statistics
Gets the size of the write-behind queue, if any.
getXaCommitCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Return the Cache's XAResource commit calls count
getXaCommitCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Return the Cache's XAResource commit calls count
getXaCommitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Return the Cache's XAResource commit calls count
getXaCommitCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Return the Cache's XAResource commit calls count
getXaCommitCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Return the Cache's XAResource commit calls count
getXaRollbackCount() - Method in class net.sf.ehcache.management.sampled.SampledCache
Return the Cache's XAResource rollback calls count
getXaRollbackCount() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Return the Cache's XAResource rollback calls count
getXaRollbackCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Return the Cache's XAResource rollback calls count
getXaRollbackCount() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Return the Cache's XAResource rollback calls count
getXaRollbackCount() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Return the Cache's XAResource rollback calls count
getXid() - Method in class net.sf.ehcache.transaction.xa.processor.XARequest
 
getXid() - Method in interface net.sf.ehcache.transaction.xa.XidTransactionID
Get the XID of this transaction ID
getXid() - Method in class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
Get the XID of this transaction ID
getXid() - Method in class net.sf.ehcache.transaction.XidTransactionIDSerializedForm
Get the original XidTransactionID's XID
GreaterThan - Class in net.sf.ehcache.search.expression
Greater than criteria
GreaterThan(String, Object) - Constructor for class net.sf.ehcache.search.expression.GreaterThan
Constructor
GreaterThanOrEqual - Class in net.sf.ehcache.search.expression
Greater than or equal criteria
GreaterThanOrEqual(String, Object) - Constructor for class net.sf.ehcache.search.expression.GreaterThanOrEqual
Constructor
GROUP_ID - Static variable in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMbeanNames
Group id for all sampled mbeans registered
GROUP_ID - Static variable in class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
Group id for all sampled mbeans registered
gt(T) - Method in class net.sf.ehcache.search.Attribute
Create a criteria where this attribute is greater than the given value

H

handleNonstopCacheException(NonStopCacheException) - Method in class net.sf.ehcache.hibernate.nonstop.HibernateNonstopCacheExceptionHandler
Handle NonStopCacheException.
hasAbortedSizeOf() - Method in class net.sf.ehcache.Cache
Check if the cache may contain elements which the SizeOf engine could not fully size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Check if the cache may contain elements which the SizeOf engine could not fully size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Check if the cache may contain elements which the SizeOf engine could not fully size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in interface net.sf.ehcache.Ehcache
Check if the cache may contain elements which the SizeOf engine could not fully size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.management.Cache
May the cache contain elements which the SizeOf engine could not fully size?
hasAbortedSizeOf() - Method in interface net.sf.ehcache.management.CacheMBean
Check if the cache may contain elements which the SizeOf engine could not fully size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Check if the store may contain elements which the SizeOf engine could not fully size.
hasAbortedSizeOf() - Method in interface net.sf.ehcache.pool.PoolAccessor
Check if the store may contain elements which the SizeOf engine could not fully size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.store.AbstractStore
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.store.MemoryStore
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in interface net.sf.ehcache.store.Store
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAbortedSizeOf() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Checks if the cache may contain elements for which the SizeOf engine gave up and only partially calculated the size.
hasAggregators() - Method in class net.sf.ehcache.search.impl.ResultsImpl
Whether the results contains aggregates
hasAggregators() - Method in class net.sf.ehcache.search.NullResults
Whether the results contains aggregates
hasAggregators() - Method in interface net.sf.ehcache.search.Results
Whether the results contains aggregates
hasAttributes() - Method in class net.sf.ehcache.search.impl.ResultsImpl
Whether the Results have cache attributes included.
hasAttributes() - Method in class net.sf.ehcache.search.NullResults
Whether the Results have cache attributes included.
hasAttributes() - Method in interface net.sf.ehcache.search.Results
Whether the Results have cache attributes included.
hasCacheEventListeners() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Returns whether or not at least one cache event listeners has been registered.
hasCacheReplicators() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Determines whether any registered listeners are CacheReplicators.
hasChildren() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Returns true if there is at least one child
hasChildren() - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Returns true if there is at least one child
hash(Object) - Static method in class net.sf.ehcache.concurrent.ConcurrencyUtil
Returns a hash code for non-null Object x.
hashCode() - Method in class net.sf.ehcache.Cache
Returns a hash code value for the object.
hashCode() - Method in class net.sf.ehcache.config.CacheWriterConfiguration.CacheWriterFactoryConfiguration
Overrided hashCode()
hashCode() - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Overrided hashCode()
hashCode() - Method in class net.sf.ehcache.config.CopyStrategyConfiguration
hashCode() - Method in class net.sf.ehcache.config.ElementValueComparatorConfiguration
hashCode() - Method in class net.sf.ehcache.config.FactoryConfiguration
Overrided hashCode()
hashCode() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
hashCode() - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
hashCode() - Method in class net.sf.ehcache.config.NonstopConfiguration
 
hashCode() - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
 
hashCode() - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
 
hashCode() - Method in class net.sf.ehcache.distribution.ConfigurableRMIClientSocketFactory
Implements the Object hashCode method.
hashCode() - Method in class net.sf.ehcache.Element
Gets the hashcode, based on the key.
hashCode() - Method in class net.sf.ehcache.search.Attribute
hashCode() - Method in class net.sf.ehcache.Status
Returns a hash code value for Status.
hashCode() - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
hashCode() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
hashCode() - Method in class net.sf.ehcache.transaction.TransactionIDImpl
hashCode() - Method in class net.sf.ehcache.transaction.xa.SerializableXid
hashCode() - Method in class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
hasKeys() - Method in class net.sf.ehcache.search.impl.ResultsImpl
Whether the Results have cache keys included.
hasKeys() - Method in class net.sf.ehcache.search.NullResults
Whether the Results have cache keys included.
hasKeys() - Method in interface net.sf.ehcache.search.Results
Whether the Results have cache keys included.
hasLockedAnything() - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Check if anything was locked in this transaction's context
hasNext() - Method in class net.sf.ehcache.util.AggregateIterator
hasOffHeapPool() - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
Checks whether the CacheManager uses a OffHeapPool
hasRegisteredListeners() - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Returns whether or not at least one cache manager event listeners has been registered.
hasValues() - Method in class net.sf.ehcache.search.impl.ResultsImpl
Whether the Results have cache values included.
hasValues() - Method in class net.sf.ehcache.search.NullResults
Whether the Results have cache values included.
hasValues() - Method in interface net.sf.ehcache.search.Results
Whether the Results have cache values included.
headSet(T) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
HIBERNATE_LOG_EXCEPTION_STACK_TRACE_PROPERTY - Static variable in class net.sf.ehcache.hibernate.nonstop.HibernateNonstopCacheExceptionHandler
Property name for logging the stack trace of the nonstop cache exception too.
HIBERNATE_THROW_EXCEPTION_ON_TIMEOUT_PROPERTY - Static variable in class net.sf.ehcache.hibernate.nonstop.HibernateNonstopCacheExceptionHandler
Property name which set as "true" will throw exceptions on timeout with hibernate
HibernateNonstopCacheExceptionHandler - Class in net.sf.ehcache.hibernate.nonstop
Class that takes care of NonStopCacheException that happens in hibernate module
HibernateStats - Interface in net.sf.ehcache.hibernate.management.api
Interface for hibernate related statistics of hibernate second level cache

HibernateStatsImpl - Class in net.sf.ehcache.hibernate.management.impl
Implementation of HibernateStats

HibernateStatsImpl(SessionFactory) - Constructor for class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Constructor accepting the backing SessionFactory
HibernateUtil - Class in net.sf.ehcache.hibernate
 
history - Variable in class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
The history of this counter
HIT_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
HIT_COLOR
HIT_DRAW_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
HIT_DRAW_COLOR
HIT_FILL_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
HIT_FILL_COLOR
hitCount - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
hit count
hitRate(T) - Method in class net.sf.ehcache.pool.impl.AbstractBalancedAccessEvictor
Return the hit rate for the supplied store.
hitRate(PoolableStore) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnDiskPoolEvictor
Return the hit rate for the supplied store.
hitRate(PoolableStore) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnHeapPoolEvictor
Return the hit rate for the supplied store.
hitRatio - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
hit ratio

I

IgnoreSizeOf - Annotation Type in net.sf.ehcache.pool.sizeof.annotations
Annotation to ignore a field, type or entire package while doing a SizeOf measurement
ilike(String) - Method in class net.sf.ehcache.search.Attribute
Create a criteria where this attribute's toString() matches the given expression See ILike for the expression syntax
ILike - Class in net.sf.ehcache.search.expression
A regular expression criteria that matches attribute string values.
ILike(String, String) - Constructor for class net.sf.ehcache.search.expression.ILike
Construct a "like" criteria for the given expression
immediateTimeout(boolean) - Method in class net.sf.ehcache.config.NonstopConfiguration
Set the value of immediateTimeout
ImmutableValueElementCopyStrategy - Class in net.sf.ehcache.store.compound
 
ImmutableValueElementCopyStrategy() - Constructor for class net.sf.ehcache.store.compound.ImmutableValueElementCopyStrategy
 
in(Collection<? extends T>) - Method in class net.sf.ehcache.search.Attribute
Create a criteria where this attribute is 'in' (ie.
includeAggregator(Aggregator...) - Method in interface net.sf.ehcache.search.Query
Request this query to aggregate the results by the given Aggregator(s)

This method may be called multiple times to request multiple aggregations

includeAttribute(Attribute<?>...) - Method in interface net.sf.ehcache.search.Query
Request that the given attribute(s) should be present in the result for this query.
includeKeys() - Method in interface net.sf.ehcache.search.Query
Request that the key object be present in the results.
includeValues() - Method in interface net.sf.ehcache.search.Query
Request that the value object be present in the results.
InCollection - Class in net.sf.ehcache.search.expression
Criteria for inclusion in a given Collection (presumably a Set) of values
InCollection(String, Collection<?>) - Constructor for class net.sf.ehcache.search.expression.InCollection
Constructor
increment() - Method in interface net.sf.ehcache.util.counter.Counter
Increment the counter by 1
increment(long) - Method in interface net.sf.ehcache.util.counter.Counter
Increment the counter by given amount
increment() - Method in class net.sf.ehcache.util.counter.CounterImpl
Increment the counter by 1
increment(long) - Method in class net.sf.ehcache.util.counter.CounterImpl
Increment the counter by given amount
increment(long, long) - Method in interface net.sf.ehcache.util.counter.sampled.SampledRateCounter
Increments the numerator and denominator by the passed values
increment(long, long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
Increments the numerator and denominator by the passed values
increment() - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
throws UnsupportedOperationException
increment(long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
throws UnsupportedOperationException
incrementLevel() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Increment and then return this node's new level.
incrementLevel() - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Increment and then return this node's new level.
indexOf(Object) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
init(Configuration, String, URL, InputStream) - Method in class net.sf.ehcache.CacheManager
initialises the CacheManager
init() - Method in interface net.sf.ehcache.distribution.CacheManagerPeerProvider
Notifies providers to initialise themselves.
init() - Method in class net.sf.ehcache.distribution.ManualRMICacheManagerPeerProvider
Notifies providers to initialise themselves.
init() - Method in class net.sf.ehcache.distribution.MulticastKeepaliveHeartbeatSender
Start the heartbeat thread
init() - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
Notifies providers to initialise themselves.
init() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Call to start the listeners and do any other required initialisation.
init() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
Notifies providers to initialise themselves.
init() - Method in interface net.sf.ehcache.event.CacheManagerEventListener
Call to start the listeners and do any other required initialisation.
init() - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Initialises the listeners, ready to receive events.
init() - Method in interface net.sf.ehcache.extension.CacheExtension
Notifies providers to initialise themselves.
init() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistrationImpl
No-op in this case
init() - Method in interface net.sf.ehcache.loader.CacheLoader
Notifies providers to initialise themselves.
init() - Method in class net.sf.ehcache.management.ManagementService
Call to register the mbeans in the mbean server and start the event listeners and do any other required initialisation.
init() - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
CacheManagerEventListener.init() - no need to do anything here
init() - Method in class net.sf.ehcache.writer.AbstractCacheWriter
Notifies writer to initialise themselves.
init() - Method in interface net.sf.ehcache.writer.CacheWriter
Notifies writer to initialise themselves.
init(Cache) - Method in interface net.sf.ehcache.writer.CacheWriterManager
Initialize the cache writer manager.
init(Cache) - Method in class net.sf.ehcache.writer.writebehind.WriteBehindManager
Initialize the cache writer manager.
init(Cache) - Method in class net.sf.ehcache.writer.writethrough.WriteThroughManager
Initialize the cache writer manager.
initialise() - Method in class net.sf.ehcache.Cache
Newly created caches do not have a Store.
initialise() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Newly created caches do not have a MemoryStore or a DiskStore.
initialise() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Newly created caches do not have a MemoryStore or a DiskStore.
initialise() - Method in interface net.sf.ehcache.Ehcache
Newly created caches do not have a MemoryStore or a DiskStore.
initialize(CacheManager, ClusteredInstanceFactory) - Method in interface net.sf.ehcache.management.provider.MBeanRegistrationProvider
Initialize MBeanRegistration if necessary for the cacheManager
initialize(CacheManager, ClusteredInstanceFactory) - Method in class net.sf.ehcache.management.provider.MBeanRegistrationProviderImpl
Initialize MBeanRegistration if necessary for the cacheManager
initialize(CacheManager, ClusteredInstanceFactory) - Method in class net.sf.ehcache.management.provider.NullMBeanRegistrationProvider
A null implementation of MBeanRegistrationProvider.initialize(CacheManager, ClusteredInstanceFactory)
initialize(CacheManager, ClusteredInstanceFactory) - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Initialize MBeanRegistration if necessary for the cacheManager
initializeEhcache(Ehcache) - Method in class net.sf.ehcache.CacheInitializationHelper
Initialize the Ehcache.
innerContent - Variable in class net.sf.ehcache.config.generator.model.AbstractNodeElement
the inner string content
insert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. A No-Op, since we are an asynchronous cache concurrency strategy.
insert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. A No-Op, since we are an asynchronous cache concurrency strategy.
insert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. A No-Op, since we are an asynchronous cache concurrency strategy.
insert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
insert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
Returns false since this is an asynchronous cache access strategy.
insert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
This cache is asynchronous hence a no-op
insert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.ReadWriteEhcacheEntityRegionAccessStrategy
A no-op since this is an asynchronous cache access strategy.
insert(Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
insertCount - Variable in class net.sf.ehcache.hibernate.management.impl.EntityStats
insertCount
installed() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory.DiskMarker
Mark the disk substitute as installed
INSTANCE - Static variable in class net.sf.ehcache.cluster.NoopCacheCluster
A singleton instance you can use rather than constructing your own.
INSTANCE - Static variable in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Singleton instance.
INSTANCE - Static variable in class net.sf.ehcache.search.NullResults
A global instance that can be freely shared with the world since this type has no state
InternalClassLoaderAwareCache - Class in net.sf.ehcache.constructs.classloader
Extension of Class Loader Aware cache to accommodate the removeAndReturnElement method.
InternalClassLoaderAwareCache(InternalEhcache, ClassLoader) - Constructor for class net.sf.ehcache.constructs.classloader.InternalClassLoaderAwareCache
Constructor
InternalEhcache - Interface in net.sf.ehcache.terracotta
This is an extension of the Ehcache interface to allow addition of new methods to Cache without breaking the public contract.
internalSetDiskCapacity(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Intended for internal use only, and subject to change.
internalSetLogging(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Intended for internal use only, and subject to change.
internalSetMemCapacity(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Intended for internal use only, and subject to change.
internalSetMemCapacityInBytes(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Intended for internal use only, and subject to change.
internalSetTimeToIdle(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Intended for internal use only, and subject to change.
internalSetTimeToLive(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Intended for internal use only, and subject to change.
intValue() - Method in class net.sf.ehcache.Status
Returns the int value of status, for backward compatibility with ehcache versions below 1.2
InvalidConfigurationException - Exception in net.sf.ehcache.config
An exception to report invalid configuration settings.
InvalidConfigurationException(String) - Constructor for exception net.sf.ehcache.config.InvalidConfigurationException
Constructs a new exception with a detailed message that explains the cause.
InvalidConfigurationException(Collection<ConfigError>) - Constructor for exception net.sf.ehcache.config.InvalidConfigurationException
Constructs a new exception with a message containing all config errors
InvalidConfigurationException(String, Collection<ConfigError>) - Constructor for exception net.sf.ehcache.config.InvalidConfigurationException
Constructs a new exception with a message containing all config errors
InvalidLockStateAfterRejoinException - Exception in net.sf.ehcache.constructs.nonstop.concurrency
Exception class signifying invalid lock state.
InvalidLockStateAfterRejoinException() - Constructor for exception net.sf.ehcache.constructs.nonstop.concurrency.InvalidLockStateAfterRejoinException
Default Constructor
InvalidLockStateAfterRejoinException(Throwable) - Constructor for exception net.sf.ehcache.constructs.nonstop.concurrency.InvalidLockStateAfterRejoinException
Constructor accepting a root cause
InvalidLockStateAfterRejoinException(String, Throwable) - Constructor for exception net.sf.ehcache.constructs.nonstop.concurrency.InvalidLockStateAfterRejoinException
Constructor accepting a root cause and a message
invoke(Object, Method, Object[]) - Method in class net.sf.ehcache.exceptionhandler.ExceptionHandlingDynamicCacheProxy
Processes a method invocation on a proxy instance and returns the result.
invoke(String, Object[], String[]) - Method in class net.sf.ehcache.management.Store
isAbort() - Method in enum net.sf.ehcache.config.SizeOfPolicyConfiguration.MaxDepthExceededBehavior
Returns true if this behavior is equal to ABORT
isAlive() - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Returns true if this SampledMBeanRegistrationProvider is alive
isAsynchronous() - Method in interface net.sf.ehcache.bootstrap.BootstrapCacheLoader
 
isAsynchronous() - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
 
isAsynchronous() - Method in class net.sf.ehcache.store.DiskStoreBootstrapCacheLoader
isAsynchronous() - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
isCacheCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Indicates whether this store provides a coherent view of all the elements in a cache.
isCacheCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Indicates whether this store provides a coherent view of all the elements in a cache.
isCacheCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Indicates whether this store provides a coherent view of all the elements in a cache.
isCacheCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Indicates whether this store provides a coherent view of all the elements in a cache.
isCacheCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Indicates whether this store provides a coherent view of all the elements in a cache.
isCacheCoherent() - Method in class net.sf.ehcache.store.AbstractStore
Indicates whether this store provides a coherent view of all the elements in a cache.
isCacheCoherent() - Method in interface net.sf.ehcache.store.Store
Indicates whether this store provides a coherent view of all the elements in a cache.
isCacheCoherent() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Indicates whether this store provides a coherent view of all the elements in a cache.
isCached(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Checks whether the key is held in the fronting cache
isCacheXA() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Check whether the [serialized value] cache is an XA enabled cache
isClearOnFlush() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
isClusterBulkLoadEnabled() - Method in class net.sf.ehcache.Cache
Returns true if at least one node in the cluster is in bulk-load mode.
isClusterBulkLoadEnabled() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns true if at least one node in the cluster is in bulk-load mode.
isClusterBulkLoadEnabled() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns true if at least one node in the cluster is in bulk-load mode.
isClusterBulkLoadEnabled() - Method in interface net.sf.ehcache.Ehcache
Returns true if at least one node in the cluster is in bulk-load mode.
isClusterBulkLoadEnabled() - Method in class net.sf.ehcache.management.sampled.SampledCache
Is the cache in bulk-load mode cluster-wide?
isClusterBulkLoadEnabled() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Is the cache in bulk-load mode cluster-wide?
isClusterCoherent() - Method in class net.sf.ehcache.Cache
Deprecated. use Cache.isClusterBulkLoadEnabled() instead
isClusterCoherent() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns true if the cache is in coherent mode cluster-wide.
isClusterCoherent() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Deprecated. Use EhcacheDecoratorAdapter.isClusterBulkLoadEnabled() instead
isClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns true if the cache is in coherent mode cluster-wide.
isClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns true if the cache is in coherent mode cluster-wide.
isClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns true if the cache is in coherent mode cluster-wide.
isClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns true if the cache is in coherent mode cluster-wide.
isClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns true if the cache is in coherent mode cluster-wide.
isClusterCoherent() - Method in interface net.sf.ehcache.Ehcache
Deprecated. Use Ehcache.isClusterBulkLoadEnabled() instead
isClusterCoherent() - Method in class net.sf.ehcache.management.sampled.SampledCache
Deprecated. use SampledCache.isClusterBulkLoadEnabled() instead
isClusterCoherent() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Deprecated. use SampledCacheMBean.isClusterBulkLoadEnabled() instead
isClusterCoherent() - Method in class net.sf.ehcache.store.AbstractStore
Returns true if the cache is in coherent mode cluster-wide.
isClusterCoherent() - Method in interface net.sf.ehcache.store.Store
Returns true if the cache is in coherent mode cluster-wide.
isClusterCoherent() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Returns true if the cache is in coherent mode cluster-wide.
isClustered() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Check whether clustering is enabled
isClusterOnline() - Method in interface net.sf.ehcache.cluster.CacheCluster
Find out if the current node is connected to the cluster or not
isClusterOnline() - Method in class net.sf.ehcache.cluster.NoopCacheCluster
Find out if the current node is connected to the cluster or not
isClusterOnline() - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Find out if the current node is connected to the cluster or not
isCoherent() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Deprecated. since 2.4 Use TerracottaConfiguration.getConsistency() instead to query the TerracottaConfiguration.Consistency or Ehcache#isNodeCoherent() to query if the node is coherent
isCommit() - Method in class net.sf.ehcache.transaction.TransactionIDSerializedForm
Get the original TransactionID's commit status
isComparable() - Method in enum net.sf.ehcache.search.attribute.AttributeType
Is this type comparable?
isCompressionEnabled() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Check whether compression is enabled
isContinue() - Method in enum net.sf.ehcache.config.SizeOfPolicyConfiguration.MaxDepthExceededBehavior
Returns true if this behavior is equal to CONTINUE
isCopyOnRead() - Method in class net.sf.ehcache.config.CacheConfiguration
Whether the Cache should copy elements it returns
isCopyOnRead() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Check whether the [serialized value] cache should use copy on read semantics
isCopyOnWrite() - Method in class net.sf.ehcache.config.CacheConfiguration
Whether the Cache should copy elements it gets
isCountBasedTuned() - Method in class net.sf.ehcache.config.CacheConfiguration
Whether this cache is Count based
isDecisionCommit() - Method in interface net.sf.ehcache.transaction.TransactionID
Check if this transaction should be committed or not
isDecisionCommit() - Method in class net.sf.ehcache.transaction.TransactionIDImpl
Check if this transaction should be committed or not
isDecisionCommit() - Method in class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
Check if this transaction should be committed or not
isDecisionRollback() - Method in interface net.sf.ehcache.transaction.xa.XidTransactionID
Check if this transaction ID has been marked for rollback
isDecisionRollback() - Method in class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
Check if this transaction ID has been marked for rollback
isDisabled() - Method in class net.sf.ehcache.Cache
Whether this cache is disabled.
isDisabled() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Whether this cache is disabled.
isDisabled() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Whether this cache is disabled.
isDisabled() - Method in interface net.sf.ehcache.Ehcache
Whether this cache is disabled.
isDiskPersistent() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
isDiskPersistent() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
isDiskPersistent() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
isDiskPersistent() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
isDiskPersistent() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
isDiskStore() - Method in class net.sf.ehcache.Cache
Whether this cache uses a disk store
isDistributed(Ehcache) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Determine if the given cache is distributed.
isElementInMemory(Serializable) - Method in class net.sf.ehcache.Cache
Whether an Element is stored in the cache in Memory, indicating a very low cost of retrieval.
isElementInMemory(Object) - Method in class net.sf.ehcache.Cache
Whether an Element is stored in the cache in Memory, indicating a very low cost of retrieval.
isElementInMemory(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Whether an Element is stored in the cache in Memory, indicating a very low cost of retrieval.
isElementInMemory(Serializable) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Whether an Element is stored in the cache in Memory, indicating a very low cost of retrieval.
isElementInMemory(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Whether an Element is stored in the cache in Memory, indicating a very low cost of retrieval.
isElementInMemory(Serializable) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Whether an Element is stored in the cache in Memory, indicating a very low cost of retrieval.
isElementInMemory(Serializable) - Method in interface net.sf.ehcache.Ehcache
Whether an Element is stored in the cache in Memory, indicating a very low cost of retrieval.
isElementInMemory(Object) - Method in interface net.sf.ehcache.Ehcache
Whether an Element is stored in the cache in Memory, indicating a very low cost of retrieval.
isElementOffHeap(Object) - Method in class net.sf.ehcache.Cache
Whether an Element is stored in the cache in off-heap memory, indicating an intermediate cost of retrieval.
isElementOnDisk(Serializable) - Method in class net.sf.ehcache.Cache
Whether an Element is stored in the cache on Disk, indicating a higher cost of retrieval.
isElementOnDisk(Object) - Method in class net.sf.ehcache.Cache
Whether an Element is stored in the cache on Disk, indicating a higher cost of retrieval.
isElementOnDisk(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Whether an Element is stored in the cache on Disk, indicating a higher cost of retrieval.
isElementOnDisk(Serializable) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Whether an Element is stored in the cache on Disk, indicating a higher cost of retrieval.
isElementOnDisk(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Whether an Element is stored in the cache on Disk, indicating a higher cost of retrieval.
isElementOnDisk(Serializable) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Whether an Element is stored in the cache on Disk, indicating a higher cost of retrieval.
isElementOnDisk(Serializable) - Method in interface net.sf.ehcache.Ehcache
Whether an Element is stored in the cache on Disk, indicating a higher cost of retrieval.
isElementOnDisk(Object) - Method in interface net.sf.ehcache.Ehcache
Whether an Element is stored in the cache on Disk, indicating a higher cost of retrieval.
isEmpty() - Method in class net.sf.ehcache.store.CacheKeySet
isEmpty() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
 
isEmpty() - Method in class net.sf.ehcache.util.SetAsList
isEmtpy() - Method in class net.sf.ehcache.util.CircularLossyQueue
Returns true if the queue is empty, otherwise false
isEnabled() - Method in class net.sf.ehcache.config.NonstopConfiguration
Returns true if nonstop is enabled in config
isEnabled() - Method in class net.sf.ehcache.management.sampled.SampledCache
Is the cache enabled?
isEnabled() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Returns if each contained cache is enabled.
isEnabled() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Returns if each cache is enabled.
isEnabled() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Is the cache enabled?
isEnterprise() - Method in class net.sf.ehcache.util.ProductInfo
 
isEternal() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
isEternal() - Method in class net.sf.ehcache.Element
 
isEternal() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
isEternal() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
isEternal() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
isEternal() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
isEvictionCandidate(Element) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Checks whether the element can be safely evicted.
isExact() - Method in class net.sf.ehcache.pool.Size
Check if the calculated size is exact
isExpired(Element) - Method in class net.sf.ehcache.Cache
Checks whether this cache element has expired.
isExpired(Element) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Checks whether this cache element has expired.
isExpired(Element) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Checks whether this cache element has expired.
isExpired(Element) - Method in interface net.sf.ehcache.Ehcache
Checks whether this cache element has expired.
isExpired() - Method in class net.sf.ehcache.Element
An element is expired if the expiration time as given by Element.getExpirationTime() is in the past.
isExpired(CacheConfiguration) - Method in class net.sf.ehcache.Element
An element is expired if the expiration time as given by Element.getExpirationTime() is in the past.
isExpired() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Check if the soft lock expired, ie: that the thread which locked it died
isExpired() - Method in interface net.sf.ehcache.transaction.SoftLock
Check if the soft lock expired, ie: that the thread which locked it died
isFrozen() - Method in class net.sf.ehcache.config.CacheConfiguration
 
isFull() - Method in class net.sf.ehcache.store.LruMemoryStore
An algorithm to tell if the MemoryStore is at or beyond its carrying capacity.
isFull() - Method in class net.sf.ehcache.store.MemoryStore
An algorithm to tell if the MemoryStore is at or beyond its carrying capacity.
isHeldByCurrentThread(LockType) - Method in class net.sf.ehcache.concurrent.ReadWriteLockSync
Returns true is this is lock is held at given level by the current thread.
isHeldByCurrentThread(LockType) - Method in interface net.sf.ehcache.concurrent.Sync
Returns true is this is lock is held at given level by the current thread.
isHibernateStatisticsSupported() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheHibernateMBean
Returns true if hibernate statistics is supported.
isHibernateStatisticsSupported() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns true if hibernate statistics is supported.
isHotspot() - Static method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Returns true if VM vendor is Hotspot
isIBM() - Static method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Returns true if VM vendor is IBM
isImmediateShutdown() - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Whether the on going keysnapshot will finish before the instance is disposed
isImmediateTimeout() - Method in class net.sf.ehcache.config.NonstopConfiguration
Returns true if immediateTimeout is set to true
isInGoogleAppEngine() - Static method in class net.sf.ehcache.util.VmUtils
 
isInitialized() - Method in interface net.sf.ehcache.management.provider.MBeanRegistrationProvider
Returns true if initialized otherwise false
isInitialized() - Method in class net.sf.ehcache.management.provider.MBeanRegistrationProviderImpl
Returns true if initialized otherwise false
isInitialized() - Method in class net.sf.ehcache.management.provider.NullMBeanRegistrationProvider
Returns true if initialized otherwise false
isInitialized() - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Returns true if initialized otherwise false
isInMemoryLimitReached(Ehcache, int) - Method in class net.sf.ehcache.store.MemoryLimitedCacheLoader
Checks whether the cache has reached the limit configured for in-memory storage
isJRockit() - Static method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Returns true if VM is JRockit
isKeyInCache(Object) - Method in class net.sf.ehcache.Cache
An inexpensive check to see if the key exists in the cache.
isKeyInCache(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
An inexpensive check to see if the key exists in the cache.
isKeyInCache(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
An inexpensive check to see if the key exists in the cache.
isKeyInCache(Object) - Method in interface net.sf.ehcache.Ehcache
An inexpensive check to see if the key exists in the cache.
isKeySerializable() - Method in class net.sf.ehcache.Element
Whether the element's key may be Serialized.
isLifespanSet() - Method in class net.sf.ehcache.Element
Whether any combination of eternal, TTL or TTI has been set.
isLocalCacheEnabled() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Returns true if local cache is enabled, otherwise false
isLocalTransactional() - Method in class net.sf.ehcache.config.CacheConfiguration
Helper method to compute whether the cache is local transactional or not
isLoggingEnabled() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
isLoggingEnabled() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
isLoggingEnabled() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
isLoggingEnabled() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
isMaxBytesLocalDiskPercentageSet() - Method in class net.sf.ehcache.config.CacheConfiguration
Checks whether the user explicitly set the maxBytesOnDiskPercentage
isMaxBytesLocalDiskSet() - Method in class net.sf.ehcache.config.Configuration
Checks whether the user explicitly set the maxBytesOnDisk
isMaxBytesLocalHeapPercentageSet() - Method in class net.sf.ehcache.config.CacheConfiguration
Checks whether the user explicitly set the maxBytesOnHeapPercentage
isMaxBytesLocalHeapSet() - Method in class net.sf.ehcache.config.Configuration
Checks whether the user explicitly set the maxBytesOnHeap
isMaxBytesLocalOffHeapPercentageSet() - Method in class net.sf.ehcache.config.CacheConfiguration
Checks whether the user explicitly set the maxBytesOffHeapPercentage
isMaxBytesLocalOffHeapSet() - Method in class net.sf.ehcache.config.Configuration
Checks whether the user explicitly set the maxBytesOffHeat
isMaxInclusive() - Method in class net.sf.ehcache.search.expression.Between
 
isMinInclusive() - Method in class net.sf.ehcache.search.expression.Between
 
isNamed() - Method in class net.sf.ehcache.CacheManager
Indicate whether the CacheManager is named or not.
isNamed() - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
 
isNodeBulkLoadEnabled() - Method in class net.sf.ehcache.Cache
Returns true if the current node is in bulk-load mode.
isNodeBulkLoadEnabled() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns true if the current node is in bulk-load mode.
isNodeBulkLoadEnabled() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns true if the current node is in bulk-load mode.
isNodeBulkLoadEnabled() - Method in interface net.sf.ehcache.Ehcache
Returns true if the current node is in bulk-load mode.
isNodeBulkLoadEnabled() - Method in class net.sf.ehcache.management.sampled.SampledCache
Is the cache in bulk-load mode locally?
isNodeBulkLoadEnabled() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Is the cache in bulk-load mode locally?
isNodeCoherent() - Method in class net.sf.ehcache.Cache
Deprecated. use Cache.isNodeBulkLoadEnabled() instead
isNodeCoherent() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns true if the cache is in coherent mode for the current node.
isNodeCoherent() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Deprecated. Use EhcacheDecoratorAdapter.isNodeBulkLoadEnabled() instead
isNodeCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns true if the cache is in coherent mode for the current node.
isNodeCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns true if the cache is in coherent mode for the current node.
isNodeCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns true if the cache is in coherent mode for the current node.
isNodeCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns true if the cache is in coherent mode for the current node.
isNodeCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns true if the cache is in coherent mode for the current node.
isNodeCoherent() - Method in interface net.sf.ehcache.Ehcache
Deprecated. Use Ehcache.isNodeBulkLoadEnabled() instead
isNodeCoherent() - Method in class net.sf.ehcache.management.sampled.SampledCache
Deprecated. use SampledCache.isNodeBulkLoadEnabled() instead
isNodeCoherent() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Deprecated. use SampledCacheMBean.isNodeBulkLoadEnabled() instead
isNodeCoherent() - Method in class net.sf.ehcache.store.AbstractStore
Returns true if the cache is in coherent mode for the current node.
isNodeCoherent() - Method in interface net.sf.ehcache.store.Store
Returns true if the cache is in coherent mode for the current node.
isNodeCoherent() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Returns true if the cache is in coherent mode for the current node.
isNonstopEnabled() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Returns true if nonstop is enabled
isNull() - Method in class net.sf.ehcache.store.disk.ods.Region
Return true if this region is null, i.e.
isOnePhase() - Method in class net.sf.ehcache.transaction.xa.processor.XARequest
 
isOptional() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Returns true if this element is optional
isOptional() - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Returns true if the attribute is optional, otherwise false
isOptional() - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Returns true if this element is optional
isOptional() - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Returns true if the attribute is optional, otherwise false
isOSX() - Static method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Return true if the VM's vendor is Apple
isOutputBehaviorEnabled(XMLGeneratorVisitor.OutputBehavior) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Returns true if the output behavior is enabled
isOverflowToDisk() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
isOverflowToDisk() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
isOverflowToDisk() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
isOverflowToDisk() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
isOverflowToDisk() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
isOverflowToOffHeap() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
isOverflowToOffHeap() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
isOverflowToOffHeap() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
isOverflowToOffHeapSet() - Method in class net.sf.ehcache.config.CacheConfiguration
Checks whether the overflowing to off heap behavior was explicitly set
isPersistent() - Method in class net.sf.ehcache.store.disk.DiskStore
Is this store persistent (data survives a JVM restart)
isPersistent() - Method in class net.sf.ehcache.store.MemoryStore
Is this store persistent (data survives a JVM restart)
isPersistent() - Method in class net.sf.ehcache.store.NullStore
Is this store persistent (data survives a JVM restart)
isPersistent() - Method in interface net.sf.ehcache.store.TierableStore
Is this store persistent (data survives a JVM restart)
isPinned(Object) - Method in class net.sf.ehcache.Cache
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Check if the key is pinned
isPinned(Object) - Method in interface net.sf.ehcache.Ehcache
Check if the key is pinned
isPinned() - Method in class net.sf.ehcache.management.sampled.SampledCache
Configuration property accessor
isPinned() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Configuration property accessor
isPinned(Object) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
isPinned(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.store.LruMemoryStore
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.store.LruMemoryStore.SpoolingLinkedHashMap
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.store.MemoryStore
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.store.NullStore
Check if the key is pinned
isPinned(Object) - Method in interface net.sf.ehcache.store.Store
Check if the key is pinned
isPinned(Object) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Check if the key is pinned
isPut(Object) - Method in interface net.sf.ehcache.transaction.xa.commands.Command
Is this command represents adding a key to the store
isPut(Object) - Method in class net.sf.ehcache.transaction.xa.commands.StorePutCommand
Is this command represents adding a key to the store
isPut(Object) - Method in class net.sf.ehcache.transaction.xa.commands.StoreRemoveCommand
Is this command represents adding a key to the store
isReadLockedByCurrentThread(Object) - Method in class net.sf.ehcache.Cache
Returns true if a read lock for the key is held by the current thread
isReadLockedByCurrentThread(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns true if a read lock for the key is held by the current thread
isReadLockedByCurrentThread(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns true if a read lock for the key is held by the current thread
isReadLockedByCurrentThread(Object) - Method in interface net.sf.ehcache.Ehcache
Returns true if a read lock for the key is held by the current thread
isRegionCacheEnabled(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns true if cache is enabled for the input region
isRegionCacheEnabled(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns true if cache is enabled for the input region
isRegionCacheEnabled(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns true if cache is enabled for the input region
isRegionCacheLoggingEnabled(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns true if logging is enabled for the input cache region
isRegionCacheLoggingEnabled(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns true if logging is enabled for the input cache region
isRegionCacheLoggingEnabled(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns true if logging is enabled for the input cache region
isRegionCacheOrphanEvictionEnabled(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns true if orphan eviction is enabled for the region otherwise false
isRegionCacheOrphanEvictionEnabled(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns true if orphan eviction is enabled for the region otherwise false
isRegionCacheOrphanEvictionEnabled(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns true if orphan eviction is enabled for the region otherwise false
isRegionCachesEnabled() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns true if all the cache regions are enabled.
isRegionCachesEnabled() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns true if all the cache regions are enabled.
isRegionCachesEnabled() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns true if all the cache regions are enabled.
isRejoin() - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Returns true if rejoin is enabled
isRemove(Object) - Method in interface net.sf.ehcache.transaction.xa.commands.Command
Is this command represents removing a key to the store
isRemove(Object) - Method in class net.sf.ehcache.transaction.xa.commands.StorePutCommand
Is this command represents removing a key to the store
isRemove(Object) - Method in class net.sf.ehcache.transaction.xa.commands.StoreRemoveCommand
Is this command represents removing a key to the store
isRemoved(Object) - Method in class net.sf.ehcache.transaction.xa.XATransactionContext
Queries the local tx context, whether the key is pending removal
isReplicateUpdatesViaCopy() - Method in interface net.sf.ehcache.distribution.CacheReplicator
Returns whether update is through copy or invalidate
isReplicateUpdatesViaCopy() - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
 
isResetOnSample() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterConfig
Returns true if counters created from this config will reset on each sample
isSameRM(XAResource) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
isSampledStatisticsEnabled() - Method in class net.sf.ehcache.Cache
Returns if sampled statistics collection is enabled or disabled
isSampledStatisticsEnabled() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns if sampled statistics collection is enabled or disabled
isSampledStatisticsEnabled() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns if sampled statistics collection is enabled or disabled
isSampledStatisticsEnabled() - Method in interface net.sf.ehcache.Ehcache
Returns if sampled statistics collection is enabled or disabled
isSampledStatisticsEnabled() - Method in class net.sf.ehcache.management.sampled.SampledCache
Returns true if statistics collection is enabled for cache, otherwise false
isSampledStatisticsEnabled() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Returns true if statistics collection is enabled for cache, otherwise false
isSampledStatisticsEnabled() - Method in interface net.sf.ehcache.statistics.sampled.SampledCacheStatistics
Returns true if statistics collection is enabled for cache, otherwise false
isSampledStatisticsEnabled() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Returns true if statistics collection is enabled for cache, otherwise false
isSampledStatisticsEnabled() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Returns true if statistics collection is enabled for cache, otherwise false
isSearchable() - Method in class net.sf.ehcache.Cache
Is this cache searchable?
isSearchable() - Method in class net.sf.ehcache.config.CacheConfiguration
Accessor
isSearchable() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Is this cache searchable?
isSearchable() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Is this cache searchable?
isSearchable() - Method in interface net.sf.ehcache.Ehcache
Is this cache searchable?
isSerializable() - Method in class net.sf.ehcache.Element
Whether the element may be Serialized.
isStatisticsEnabled() - Method in class net.sf.ehcache.Cache
Returns true if statistics collection is enabled
isStatisticsEnabled() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns true if statistics collection is enabled
isStatisticsEnabled() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns true if statistics collection is enabled
isStatisticsEnabled() - Method in interface net.sf.ehcache.Ehcache
Returns true if statistics collection is enabled
isStatisticsEnabled() - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns true if statistics collection is enabled
isStatisticsEnabled() - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Returns true if statistics collection is enabled otherwise false
isStatisticsEnabled() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns true if statistics collection is enabled
isStatisticsEnabled() - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns true if statistics collection is enabled
isStatisticsEnabled() - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Returns true if statistics collection is enabled otherwise false
isStatisticsEnabled() - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Returns true if statistics collection is enabled otherwise false
isStatisticsEnabled() - Method in class net.sf.ehcache.management.sampled.SampledCache
Returns true if statistics is enabled
isStatisticsEnabled() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Returns true iff each contained cache has statistics enabled
isStatisticsEnabled() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Returns true iff each contained cache has statistics enabled
isStatisticsEnabled() - Method in interface net.sf.ehcache.statistics.LiveCacheStatistics
Returns true if statistics is enabled
isStatisticsEnabled() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Returns true if statistics is enabled
isStatisticsEnabled() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Returns true if statistics is enabled
isStatisticsEnabled() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Returns true if statistics is enabled
isStorageStrategySet() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Returns true is storageStrategy is set explicitly
isSupportedType(Object) - Static method in enum net.sf.ehcache.search.attribute.AttributeType
Test the given value to see if it is a legal type
isSynchronousWrites() - Method in class net.sf.ehcache.config.TerracottaConfiguration
Is the cache configured for synchronous-write?
isTerracottaClustered() - Method in class net.sf.ehcache.Cache
Indicates whether this cache is clustered by Terracotta
isTerracottaClustered() - Method in class net.sf.ehcache.config.CacheConfiguration
Helper method to compute whether the cache is clustered or not
isTerracottaClustered() - Method in class net.sf.ehcache.management.Cache
Is the cache configured with Terracotta clustering?
isTerracottaClustered() - Method in class net.sf.ehcache.management.CacheConfiguration
Accessor
isTerracottaClustered() - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Accessor
isTerracottaClustered() - Method in interface net.sf.ehcache.management.CacheMBean
Uses a Terracotta clustered store.
isTerracottaClustered() - Method in class net.sf.ehcache.management.sampled.SampledCache
Is the cache configured with Terracotta clustering?
isTerracottaClustered() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Is the cache configured with Terracotta clustering?
isTerracottaHibernateCache(String) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Returns true if the input region is clustered with terracotta
isTerracottaHibernateCache(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Returns true if the input region is clustered with terracotta
isTerracottaHibernateCache(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Returns true if the input region is clustered with terracotta
isTerracottaRejoin() - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
 
isTierPinned() - Method in class net.sf.ehcache.store.disk.DiskStore
Is this TierableStore pinned ?
isTierPinned() - Method in class net.sf.ehcache.store.MemoryStore
Is this TierableStore pinned ?
isTierPinned() - Method in class net.sf.ehcache.store.NullStore
Is this TierableStore pinned ?
isTierPinned() - Method in interface net.sf.ehcache.store.TierableStore
Is this TierableStore pinned ?
isTransactional() - Method in enum net.sf.ehcache.config.CacheConfiguration.TransactionalMode
 
isTransactionAware() - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
isTransactionStarted(Ehcache) - Static method in class net.sf.ehcache.util.CacheTransactionHelper
Check if a transaction has begun on the current thread if the cache is configured as transactional, otherwise always return false.
isUpdate() - Method in exception net.sf.ehcache.store.disk.StoreUpdateException
Whether the element was inserted or updated in the Store
isUrlConfig() - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Helper to check whether this is url config or embedded config
isValid() - Method in class net.sf.ehcache.distribution.LegacyEventMessage
 
isValidStatisticsAccuracy(int) - Static method in class net.sf.ehcache.Statistics
Utility method to determine if a given value is a valid statistics accuracy value or not
isValidTimeoutBehaviorType(String) - Static method in enum net.sf.ehcache.config.TimeoutBehaviorConfiguration.TimeoutBehaviorType
Find out if a string is a valid timeoutBehavior type or not
isValueInCache(Object) - Method in class net.sf.ehcache.Cache
An extremely expensive check to see if the value exists in the cache.
isValueInCache(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
An extremely expensive check to see if the value exists in the cache.
isValueInCache(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
An extremely expensive check to see if the value exists in the cache.
isValueInCache(Object) - Method in interface net.sf.ehcache.Ehcache
An extremely expensive check to see if the value exists in the cache.
isWriteLockedByCurrentThread(Object) - Method in class net.sf.ehcache.Cache
Returns true if a write lock for the key is held by the current thread
isWriteLockedByCurrentThread(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns true if a write lock for the key is held by the current thread
isWriteLockedByCurrentThread(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns true if a write lock for the key is held by the current thread
isWriteLockedByCurrentThread(Object) - Method in interface net.sf.ehcache.Ehcache
Returns true if a write lock for the key is held by the current thread
isXaStrictTransactional() - Method in class net.sf.ehcache.config.CacheConfiguration
Helper method to compute whether the cache is XA transactional or not
isXaTransactional() - Method in class net.sf.ehcache.config.CacheConfiguration
Helper method to compute whether the cache is local_jta transactional or not
iterator() - Method in class net.sf.ehcache.constructs.nonstop.concurrency.NonStopCacheKeySet
Iterator to iterate over the key set May time out
iterator() - Method in class net.sf.ehcache.store.CacheKeySet
iterator() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
 
iterator() - Method in class net.sf.ehcache.util.LargeCollection
iterator() - Method in class net.sf.ehcache.util.SetAsList

J

JavaBeanAttributeExtractor - Class in net.sf.ehcache.search.attribute
 
JavaBeanAttributeExtractor(String) - Constructor for class net.sf.ehcache.search.attribute.JavaBeanAttributeExtractor
Constructor
JtaLocalTransactionStore - Class in net.sf.ehcache.transaction.local
A Store implementation with support for local transactions driven by a JTA transaction manager
JtaLocalTransactionStore(LocalTransactionStore, TransactionManagerLookup, TransactionController) - Constructor for class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Create a new JtaLocalTransactionStore instance
JvmInformation - Enum in net.sf.ehcache.pool.sizeof
Detects and represents JVM-specific properties that relate to the memory data model for java objects that are useful for size of calculations.

K

KEY - Static variable in interface net.sf.ehcache.search.Query
The search attribute for a cache element's key.
KeyBasedOperation - Interface in net.sf.ehcache.writer.writebehind.operations
Interface to implement operations that are performed with write-behind and based on a key
KeyObjectAttributeExtractor - Class in net.sf.ehcache.search.attribute
Attempt to use the element key object itself as a search attribute.
KeyObjectAttributeExtractor() - Constructor for class net.sf.ehcache.search.attribute.KeyObjectAttributeExtractor
 
keys() - Method in class net.sf.ehcache.config.Searchable
Are keys searchable?
keys(boolean) - Method in class net.sf.ehcache.config.Searchable
Toggle searchable keys
KEYS_DEFAULT - Static variable in class net.sf.ehcache.config.Searchable
Default for auto-searchable keys
keySet() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
keySet() - Method in class net.sf.ehcache.store.disk.DiskStore
Get a set view of the keys in this store
keySet() - Method in class net.sf.ehcache.store.MemoryStore
Returns the keySet for this store
keySet() - Method in class net.sf.ehcache.util.WeakIdentityConcurrentMap
 

L

LargeCollection<E> - Class in net.sf.ehcache.util
Collection for large set.
LargeCollection() - Constructor for class net.sf.ehcache.util.LargeCollection
default constructor.
LargeSet<E> - Class in net.sf.ehcache.util
Set for holding large entries of set.
LargeSet() - Constructor for class net.sf.ehcache.util.LargeSet
 
last() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
lastIndexOf(Object) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
le(T) - Method in class net.sf.ehcache.search.Attribute
Create a criteria where this attribute is less than or equal to the given value
LegacyCopyStrategyAdapter - Class in net.sf.ehcache.store.compound
ReadWriteCopyStrategy adaptor for a legacy CopyStrategy instance
LegacyCopyStrategyAdapter(CopyStrategy) - Constructor for class net.sf.ehcache.store.compound.LegacyCopyStrategyAdapter
create a LegacyCopyStrategyAdapter
LegacyEventMessage - Class in net.sf.ehcache.distribution
An Event Message, in respect of a particular cache.
LegacyEventMessage(int, Serializable, Element) - Constructor for class net.sf.ehcache.distribution.LegacyEventMessage
Full constructor.
LegacyStoreWrapper - Class in net.sf.ehcache.store
A wrapper to convert a legacy pair of stores into a new style compound store.
LegacyStoreWrapper(Store, Store, RegisteredEventListeners, CacheConfiguration) - Constructor for class net.sf.ehcache.store.LegacyStoreWrapper
Create a correctly locked store wrapper around the supplied in-memory and on disk stores.
LessThan - Class in net.sf.ehcache.search.expression
Less than criteria
LessThan(String, Object) - Constructor for class net.sf.ehcache.search.expression.LessThan
Constructor
LessThanOrEqual - Class in net.sf.ehcache.search.expression
Less than or equal criteria
LessThanOrEqual(String, Object) - Constructor for class net.sf.ehcache.search.expression.LessThanOrEqual
Constructor
LFU - Static variable in class net.sf.ehcache.store.MemoryStoreEvictionPolicy
LFU - least frequently used.
LfuPolicy - Class in net.sf.ehcache.store
Contains common LFU policy code for use between the LfuMemoryStore and the DiskStore, which also uses an LfuPolicy for evictions.
LfuPolicy() - Constructor for class net.sf.ehcache.store.LfuPolicy
 
listBoundRMICachePeers() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Returns a list of bound objects.
listeners - Variable in class net.sf.ehcache.config.CacheConfiguration
The listeners for this configuration.
listenFor(String) - Method in class net.sf.ehcache.config.CacheConfiguration.CacheEventListenerFactoryConfiguration
 
listIterator() - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
listIterator(int) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
listRemoteCachePeers(Ehcache) - Method in interface net.sf.ehcache.distribution.CacheManagerPeerProvider
 
listRemoteCachePeers(Ehcache) - Method in class net.sf.ehcache.distribution.ManualRMICacheManagerPeerProvider
 
listRemoteCachePeers(Ehcache) - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
 
listRemoteCachePeers(Ehcache) - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Package protected List of cache peers
listRemoteCachePeers(Ehcache) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
 
LiveCacheStatistics - Interface in net.sf.ehcache.statistics
Interface for usage statistics of a Cache.
LiveCacheStatisticsData - Interface in net.sf.ehcache.statistics
Interface that classes storing usage statistics of a Cache will implement
LiveCacheStatisticsImpl - Class in net.sf.ehcache.statistics
Implementation which can be used both as a LiveCacheStatistics and LiveCacheStatisticsData
LiveCacheStatisticsImpl(Ehcache) - Constructor for class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Constructor that accepts the backing Ehcache, needed for LiveCacheStatisticsImpl.getSize()
LiveCacheStatisticsWrapper - Class in net.sf.ehcache.statistics
An implementation of LiveCacheStatistics and also implements LiveCacheStatisticsData.
LiveCacheStatisticsWrapper(Ehcache) - Constructor for class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Constructor accepting the backing cache.
liveness() - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Synchronized version of getName to test liveness of the object lock.
load(Ehcache) - Method in interface net.sf.ehcache.bootstrap.BootstrapCacheLoader
Instructs the loader to load the given cache
load(Object) - Method in class net.sf.ehcache.Cache
The load method provides a means to "pre-load" the cache.
load(Object) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
This method is not appropriate to use with BlockingCache.
load(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
The load method provides a means to "pre load" the cache.
load(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
The load method provides a means to "pre load" the cache.
load(Ehcache) - Method in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Bootstraps the cache from a random CachePeer.
load(Object) - Method in interface net.sf.ehcache.Ehcache
The load method provides a means to "pre load" the cache.
load(Object) - Method in interface net.sf.ehcache.loader.CacheLoader
loads an object.
load(Object, Object) - Method in interface net.sf.ehcache.loader.CacheLoader
Load using both a key and an argument.
load(Ehcache) - Method in class net.sf.ehcache.store.DiskStoreBootstrapCacheLoader
Instructs the loader to load the given cache
load(Ehcache) - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Instructs the loader to load the given cache
loadAll(Collection, Object) - Method in class net.sf.ehcache.Cache
The loadAll method provides a means to "pre load" objects into the cache.
loadAll(Collection, Object) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
This method is not appropriate to use with BlockingCache.
loadAll(Collection, Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
The loadAll method provides a means to "pre load" objects into the cache.
loadAll(Collection, Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
The loadAll method provides a means to "pre load" objects into the cache.
loadAll(Collection, Object) - Method in interface net.sf.ehcache.Ehcache
The loadAll method provides a means to "pre load" objects into the cache.
loadAll(Collection) - Method in interface net.sf.ehcache.loader.CacheLoader
loads multiple object.
loadAll(Collection, Object) - Method in interface net.sf.ehcache.loader.CacheLoader
Load using both a key and an argument.
loadClass(String) - Static method in class net.sf.ehcache.util.ClassLoaderUtil
Load the given class by name
loadCount - Variable in class net.sf.ehcache.hibernate.management.impl.CollectionStats
loadCount
loadCount - Variable in class net.sf.ehcache.hibernate.management.impl.EntityStats
loadCount
LoaderTimeoutException - Exception in net.sf.ehcache
A loader timeout Exception.
LoaderTimeoutException() - Constructor for exception net.sf.ehcache.LoaderTimeoutException
Constructor for the LoaderTimeoutException object.
LoaderTimeoutException(String) - Constructor for exception net.sf.ehcache.LoaderTimeoutException
Constructor for the LoaderTimeoutException object.
LoaderTimeoutException(String, Throwable) - Constructor for exception net.sf.ehcache.LoaderTimeoutException
Constructs a new LoaderTimeoutException with the specified detail message and cause.
LoaderTimeoutException(Throwable) - Constructor for exception net.sf.ehcache.LoaderTimeoutException
Constructs a new LoaderTimeoutException with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
LOCAL_READS_TYPE_NAME - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Type name for TimeoutBehaviorConfiguration.TimeoutBehaviorType.LOCAL_READS
localCacheEnabled(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Enable or disable the local cache
localKeyCache(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
localKeyCacheSize(int) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
LocalReadsOnTimeoutStore - Class in net.sf.ehcache.constructs.nonstop.store
A NonstopStore implementation that returns the local value in the VM, if present, for get operations and no-op for put, remove and other operations
LocalReadsOnTimeoutStore(NonstopActiveDelegateHolder) - Constructor for class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Constructor accepting the NonstopActiveDelegateHolder
LocalTransactionContext - Class in net.sf.ehcache.transaction.local
A local transaction's thread context
LocalTransactionContext(int, TransactionID) - Constructor for class net.sf.ehcache.transaction.local.LocalTransactionContext
Create a new LocalTransactionContext
LocalTransactionStore - Class in net.sf.ehcache.transaction.local
A Store implementation with support for local transactions
LocalTransactionStore(TransactionController, SoftLockFactory, Ehcache, Store, ReadWriteCopyStrategy<Element>) - Constructor for class net.sf.ehcache.transaction.local.LocalTransactionStore
Create a new LocalTransactionStore instance
lock(LockType) - Method in class net.sf.ehcache.concurrent.ReadWriteLockSync
Acquire lock of LockType.READ or WRITE
lock(LockType) - Method in interface net.sf.ehcache.concurrent.Sync
Acquire lock of LockType.READ or WRITE
lock(Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. Caching is non-strict so soft locks are not implemented.
lock(Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. Throws UnsupportedOperationException since items in a read-only cache should not be mutated.
lock(Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. Soft-locks the associated mapping prior to updating/inserting a new value.
lock(Object) - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. 
lock() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Lock the soft lock
lock() - Method in interface net.sf.ehcache.transaction.SoftLock
Lock the soft lock
lockFor(Object) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
lockItem(Object, Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
lockItem(Object, Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
lockItem(Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheCollectionRegionAccessStrategy
Since this is a non-strict read/write strategy item locking is not used.
lockItem(Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
Since this is a non-strict read/write strategy item locking is not used.
lockItem(Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheCollectionRegionAccessStrategy
Throws UnsupportedOperationException since this cache is read-only
lockItem(Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
Throws UnsupportedOperationException since this cache is read-only
lockItem(Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheCollectionRegionAccessStrategy
lockItem(Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
LockOperationTimedOutNonstopException - Exception in net.sf.ehcache.constructs.nonstop.concurrency
Special class of NonStopCacheException which is thrown on timeout of lock operations
LockOperationTimedOutNonstopException(String) - Constructor for exception net.sf.ehcache.constructs.nonstop.concurrency.LockOperationTimedOutNonstopException
public constructor
lockRegion() - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
lockRegion() - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
locks() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
locksAreIndependentOfCache() - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Returns true if the locks used by the locking methods of this region are the independent of the cache.
LockTimeoutException - Exception in net.sf.ehcache.constructs.blocking
Indicates that a timeout has occured while attempting to obtain a lock using ReadWriteLockSync.tryLock(net.sf.ehcache.concurrent.LockType, long)

This is a normal runtime exception which should be handled by calling code.

LockTimeoutException() - Constructor for exception net.sf.ehcache.constructs.blocking.LockTimeoutException
Constructs a new runtime exception with null as its detail message.
LockTimeoutException(String) - Constructor for exception net.sf.ehcache.constructs.blocking.LockTimeoutException
Constructs a new runtime exception with the specified detail message.
LockTimeoutException(String, Throwable) - Constructor for exception net.sf.ehcache.constructs.blocking.LockTimeoutException
Constructor for the LockTimeoutException object.
LockType - Enum in net.sf.ehcache.concurrent
LockType tells the locking API what kind of lock should be acquired or released
logging - Variable in class net.sf.ehcache.config.CacheConfiguration
Indicates whether logging is enabled or not.
logging(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder to enable or disable logging for the cache

This property can be modified dynamically while the cache is operating.

loggingChanged(boolean, boolean) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates a change in the configuration for enable/disable logging
loggingChanged(boolean, boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates a change in the configuration for enable/disable logging
loggingChanged(boolean, boolean) - Method in class net.sf.ehcache.store.MemoryStore
Indicates a change in the configuration for enable/disable logging
lookupPeer(String) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Returns a reference to the remote object.
lookupRemoteCachePeer(String) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
The use of one-time registry creation and Naming.rebind should mean we can create as many listeneres as we like.
LRU - Static variable in class net.sf.ehcache.store.MemoryStoreEvictionPolicy
LRU - least recently used.
LruMemoryStore - Class in net.sf.ehcache.store
An implementation of a LruMemoryStore.
LruMemoryStore(Ehcache, Store) - Constructor for class net.sf.ehcache.store.LruMemoryStore
Constructor for the LruMemoryStore object The backing LinkedHashMap is created with LRU by access order.
LruMemoryStore.SpoolingLinkedHashMap - Class in net.sf.ehcache.store
An extension of LinkedHashMap which overrides LruMemoryStore.SpoolingLinkedHashMap.removeEldestEntry(java.util.Map.Entry) to persist cache entries to the auxiliary cache before they are removed.
LruMemoryStore.SpoolingLinkedHashMap() - Constructor for class net.sf.ehcache.store.LruMemoryStore.SpoolingLinkedHashMap
Default constructor.
LruPolicy - Class in net.sf.ehcache.store
Contains common LFU policy code for use between the LfuMemoryStore and the DiskStore, which also uses an LfuPolicy for evictions.
LruPolicy() - Constructor for class net.sf.ehcache.store.LruPolicy
 
lt(T) - Method in class net.sf.ehcache.search.Attribute
Create a criteria where this attribute is less than the given value
luceneStringCompare(String, String) - Static method in class net.sf.ehcache.search.expression.ComparableValue
Perform a Lucene compatible case insensitive string comparison.

M

main(String[]) - Static method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Generator for the method bodies
makeAndCheckElement(Object, Object) - Static method in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Both CacheEntryFactory can return an Element rather than just a regular value this method test this, making a fresh Element otherwise.
ManagedCacheManagerPeerProvider - Interface in net.sf.ehcache.management
A CacheManagerPeerProvider that supports MBean registration
ManagementService - Class in net.sf.ehcache.management
Ehcache CacheManagers and Caches have lifecycles.
ManagementService(CacheManager, MBeanServer, boolean, boolean, boolean, boolean, boolean) - Constructor for class net.sf.ehcache.management.ManagementService
A constructor for a management service for a range of possible MBeans.
ManagementService(CacheManager, MBeanServer, boolean, boolean, boolean, boolean) - Constructor for class net.sf.ehcache.management.ManagementService
A constructor for a management service for a range of possible MBeans.
ManualRMICacheManagerPeerProvider - Class in net.sf.ehcache.distribution
A provider of Peer RMI addresses based off manual configuration.
ManualRMICacheManagerPeerProvider() - Constructor for class net.sf.ehcache.distribution.ManualRMICacheManagerPeerProvider
Empty constructor.
map - Variable in class net.sf.ehcache.store.LruMemoryStore
Map where items are stored by key.
mark(Region) - Method in class net.sf.ehcache.store.disk.ods.FileAllocationTree
Mark this region as used
markForCommit() - Method in interface net.sf.ehcache.transaction.TransactionID
Mark that this transaction's decision is commit
markForCommit() - Method in class net.sf.ehcache.transaction.TransactionIDImpl
Mark that this transaction's decision is commit
markForCommit() - Method in class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
Mark that this transaction's decision is commit
markForRollback() - Method in interface net.sf.ehcache.transaction.xa.XidTransactionID
Mark this transaction ID for rollback
markForRollback() - Method in class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
Mark this transaction ID for rollback
markUsed(DiskStorageFactory.DiskMarker) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Mark this on-disk marker as used (hooks into the file space allocation structure).
max(Attribute<?>) - Static method in class net.sf.ehcache.search.aggregator.Aggregators
Construct a maximum value aggregator
Max<T> - Class in net.sf.ehcache.search.aggregator
Determine the maximum value
Max(Attribute<?>) - Constructor for class net.sf.ehcache.search.aggregator.Max
 
max() - Method in class net.sf.ehcache.search.Attribute
Request a maximum value aggregation of this attribute
maxBytesLocalDisk(long, MemoryUnit) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the maxOnDisk size
maxBytesLocalDisk(long, MemoryUnit) - Method in class net.sf.ehcache.config.Configuration
Sets the maxOnDisk size
maxBytesLocalDiskChanged(long, long) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates a change in the configuration for maxBytesLocalDisk setting
maxBytesLocalDiskChanged(long, long) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates a change in the configuration for maxBytesLocalDisk setting
maxBytesLocalDiskChanged(long, long) - Method in class net.sf.ehcache.store.MemoryStore
Indicates a change in the configuration for maxBytesLocalDisk setting
maxBytesLocalHeap(long, MemoryUnit) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the maxOnHeap size
maxBytesLocalHeap(long, MemoryUnit) - Method in class net.sf.ehcache.config.Configuration
Sets the maxOnHeap size for the cache being configured
maxBytesLocalHeapChanged(long, long) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates a change in the configuration for maxBytesLocalHeap setting
maxBytesLocalHeapChanged(long, long) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates a change in the configuration for maxBytesLocalHeap setting
maxBytesLocalHeapChanged(long, long) - Method in class net.sf.ehcache.store.MemoryStore
Indicates a change in the configuration for maxBytesLocalHeap setting
maxBytesLocalOffHeap(long, MemoryUnit) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the maxOffHeap tier size
maxBytesLocalOffHeap(long, MemoryUnit) - Method in class net.sf.ehcache.config.Configuration
Sets the maximum size for the OffHeap tier for all the caches this CacheManagers holds.
maxDepth(int) - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Builder method to set the maximum depth the SizeOf engine can normally traverse
maxDepthExceededBehavior(SizeOfPolicyConfiguration.MaxDepthExceededBehavior) - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Builder method to set the behavior of the SizeOf engine when the max depth is reached
maxDepthExceededBehavior(String) - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Builder method to set the behavior of the SizeOf engine when the max depth is reached using a String object
MaxDepthExceededException - Exception in net.sf.ehcache.pool.sizeof
 
MaxDepthExceededException(String) - Constructor for exception net.sf.ehcache.pool.sizeof.MaxDepthExceededException
Constructor
maxElementsInMemory(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Deprecated. use CacheConfiguration.maxEntriesLocalHeap(int)
maxElementsOnDisk - Variable in class net.sf.ehcache.config.CacheConfiguration
the maximum objects to be held in the DiskStore.
maxElementsOnDisk(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the maximum number elements on Disk.
maxEntriesLocalDisk(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the maximum number elements on Disk.
maxEntriesLocalHeap - Variable in class net.sf.ehcache.config.CacheConfiguration
the maximum objects to be held in the MemoryStore.
maxEntriesLocalHeap(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder that sets the maximum objects to be held in memory (0 = no limit).
MAXIMUM_CHUNK_SIZE_BYTES - Static variable in class net.sf.ehcache.distribution.RMIBootstrapCacheLoaderFactory
The property name expected in ehcache.xml for the maximum chunk size in bytes
maximumChunkSizeBytes - Variable in class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
The maximum serialized size of the elements to request from a remote cache peer during bootstrap.
maximumSize - Variable in class net.sf.ehcache.store.LruMemoryStore
The maximum size of the store (0 == no limit)
maxMemoryOffHeap(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder to set the max off heap memory size allocated for this cache.
maxResults(int) - Method in interface net.sf.ehcache.search.Query
Restrict the number of results returned from the search.
maxResults() - Method in interface net.sf.ehcache.store.StoreQuery
Get the maximum number of results to return
maxWriteDelay(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
MBeanRegistrationProvider - Interface in net.sf.ehcache.management.provider
Implementations of this interface will can initialize MBeanRegistration for the passed CacheManager.
MBeanRegistrationProviderException - Exception in net.sf.ehcache.management.provider
Exception thrown from MBeanRegistrationProvider

MBeanRegistrationProviderException(String, Throwable) - Constructor for exception net.sf.ehcache.management.provider.MBeanRegistrationProviderException
Constructor accepting a string message and a Throwable
MBeanRegistrationProviderException(String) - Constructor for exception net.sf.ehcache.management.provider.MBeanRegistrationProviderException
Constructor accepting a message
MBeanRegistrationProviderFactory - Interface in net.sf.ehcache.management.provider
Factory interface to create MBeanRegistrationProvider

MBeanRegistrationProviderFactoryImpl - Class in net.sf.ehcache.management.provider
Defult implementation of MBeanRegistrationProvider

MBeanRegistrationProviderFactoryImpl() - Constructor for class net.sf.ehcache.management.provider.MBeanRegistrationProviderFactoryImpl
 
MBeanRegistrationProviderImpl - Class in net.sf.ehcache.management.provider
Implementation of MBeanRegistrationProvider

MBeanRegistrationProviderImpl(Configuration) - Constructor for class net.sf.ehcache.management.provider.MBeanRegistrationProviderImpl
Constructor accepting the Configuration
mbeanSafe(String) - Static method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMbeanNames
Filter out invalid ObjectName characters from s.
memoryCapacityChanged(int, int) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates a change in the configurations memory store capacity
memoryCapacityChanged(int, int) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates a change in the configurations memory store capacity
memoryCapacityChanged(int, int) - Method in class net.sf.ehcache.store.MemoryStore
Indicates a change in the configurations memory store capacity
MemoryEfficientByteArrayOutputStream - Class in net.sf.ehcache.util
This class is designed to minimise the number of System.arraycopy(); methods required to complete.
MemoryEfficientByteArrayOutputStream(int) - Constructor for class net.sf.ehcache.util.MemoryEfficientByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
MemoryLimitedCacheLoader - Class in net.sf.ehcache.store
Abstract class for BootstrapCacheLoader implementers that should alter their load behavior (probably stop loading) whenever the cache being bootstrapped has reached its in-memory limit (off- or on-heap)
MemoryLimitedCacheLoader() - Constructor for class net.sf.ehcache.store.MemoryLimitedCacheLoader
 
MemoryOnlyStore - Class in net.sf.ehcache.store
A memory-only store with support for all caching features.
MemorySizeParser - Class in net.sf.ehcache.util
Memory size parser using the letter k or K to indicate kilobytes, the letter m or M to indicate megabytes, the letter g or G to indicate gigabytes and the letter t or T to indicate terabytes.
MemorySizeParser() - Constructor for class net.sf.ehcache.util.MemorySizeParser
 
MemoryStore - Class in net.sf.ehcache.store
A Store implementation suitable for fast, concurrent in memory stores.
MemoryStore(Ehcache, Pool, boolean) - Constructor for class net.sf.ehcache.store.MemoryStore
Constructs things that all MemoryStores have in common.
memoryStoreEvictionPolicy - Variable in class net.sf.ehcache.config.CacheConfiguration
The policy used to evict elements from the MemoryStore.
memoryStoreEvictionPolicy(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder that sets the eviction policy.
memoryStoreEvictionPolicy(MemoryStoreEvictionPolicy) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which Sets the eviction policy.
MemoryStoreEvictionPolicy - Class in net.sf.ehcache.store
A typesafe enumeration of eviction policies.
MemoryStoreEvictionPolicy.MemoryStoreEvictionPolicyEnum - Enum in net.sf.ehcache.store
Enum for MemoryStoreEvictionPolicy
MemoryUnit - Enum in net.sf.ehcache.config
Memory unit: byte-based
merge(Region) - Method in class net.sf.ehcache.store.disk.ods.Region
Merge the supplied region into this region (if they are adjoining).
metadata - Variable in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Metadata associated with the objects stored in the region.
MimeTypeByteArray - Class in net.sf.ehcache
A bean used to wrap byte[] values to be placed in an Element so as to preserve MIME type information.
MimeTypeByteArray() - Constructor for class net.sf.ehcache.MimeTypeByteArray
Empty constructor, as required for JavaBeans
MimeTypeByteArray(String, byte[]) - Constructor for class net.sf.ehcache.MimeTypeByteArray
Full constructor
min(Attribute<?>) - Static method in class net.sf.ehcache.search.aggregator.Aggregators
Construct a minimum value aggregator
Min<T> - Class in net.sf.ehcache.search.aggregator
Determine the minimum value
Min(Attribute<?>) - Constructor for class net.sf.ehcache.search.aggregator.Min
 
min() - Method in class net.sf.ehcache.search.Attribute
Request a minimum value aggregation of this attribute
minWriteDelay(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
miss() - Method in class net.sf.ehcache.store.disk.Segment
Record a miss in the disk tier
MISS_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
MISS_COLOR
MISS_DRAW_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
MISS_DRAW_COLOR
MISS_FILL_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
MISS_FILL_COLOR
missCount - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
miss count
missRate(T) - Method in class net.sf.ehcache.pool.impl.AbstractBalancedAccessEvictor
Return the miss rate for the supplied store.
missRate(PoolableStore) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnDiskPoolEvictor
Return the miss rate for the supplied store.
missRate(PoolableStore) - Method in class net.sf.ehcache.pool.impl.BalancedAccessOnHeapPoolEvictor
Return the miss rate for the supplied store.
modCount - Variable in class net.sf.ehcache.store.disk.Segment
Mod-count used to track concurrent modifications when doing size calculations or iterating over the store.
monitoring(Configuration.Monitoring) - Method in class net.sf.ehcache.config.Configuration
Builder to set the monitoring approach
MulticastKeepaliveHeartbeatReceiver - Class in net.sf.ehcache.distribution
Receives heartbeats from any MulticastKeepaliveHeartbeatSenders out there.
MulticastKeepaliveHeartbeatReceiver(MulticastRMICacheManagerPeerProvider, InetAddress, Integer, InetAddress) - Constructor for class net.sf.ehcache.distribution.MulticastKeepaliveHeartbeatReceiver
Constructor.
MulticastKeepaliveHeartbeatSender - Class in net.sf.ehcache.distribution
Sends heartbeats to a multicast group containing a compressed list of URLs.
MulticastKeepaliveHeartbeatSender(CacheManager, InetAddress, Integer, Integer, InetAddress) - Constructor for class net.sf.ehcache.distribution.MulticastKeepaliveHeartbeatSender
Constructor.
MulticastRMICacheManagerPeerProvider - Class in net.sf.ehcache.distribution
A peer provider which discovers peers using Multicast.
MulticastRMICacheManagerPeerProvider(CacheManager, InetAddress, Integer, Integer, InetAddress) - Constructor for class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
Creates and starts a multicast peer provider
MulticastRMICacheManagerPeerProvider.CachePeerEntry - Class in net.sf.ehcache.distribution
Entry containing a looked up CachePeer and date
MulticastRMICacheManagerPeerProvider.CachePeerEntry(CachePeer, Date) - Constructor for class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider.CachePeerEntry
Constructor

N

name - Variable in class net.sf.ehcache.config.CacheConfiguration
the name of the cache.
name(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder to set the name of the cache.
name(String) - Method in class net.sf.ehcache.config.Configuration
Builder to set the cache manager name.
name(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the attribute name
name - Variable in class net.sf.ehcache.hibernate.management.impl.EntityStats
name
NAME - Static variable in class net.sf.ehcache.store.FifoPolicy
The name of this policy as a string literal
NAME - Static variable in class net.sf.ehcache.store.LfuPolicy
The name of this policy as a string literal
NAME - Static variable in class net.sf.ehcache.store.LruPolicy
The name of this policy as a string literal
NamedThreadFactory - Class in net.sf.ehcache.util
A ThreadFactory that sets names to the threads created by this factory.
NamedThreadFactory(String) - Constructor for class net.sf.ehcache.util.NamedThreadFactory
Constructor accepting the prefix of the threads that will be created by this ThreadFactory
ne(T) - Method in class net.sf.ehcache.search.Attribute
Create a criteria where this attribute is not equal to the given value
net.sf.ehcache - package net.sf.ehcache
This package contains the public API for using ehcache.
net.sf.ehcache.bootstrap - package net.sf.ehcache.bootstrap
This package contains the bootstrap cache loader interface and abstract factory.
net.sf.ehcache.cluster - package net.sf.ehcache.cluster
This package contains the API for accessing the cluster node topology and registering to receive events about changes in the cluster node topology.
net.sf.ehcache.concurrent - package net.sf.ehcache.concurrent
This package contains concurrency classes and utilities that are not available in java.util.concurrent.
net.sf.ehcache.config - package net.sf.ehcache.config
This package contains the cache configuration code.
net.sf.ehcache.config.generator - package net.sf.ehcache.config.generator
This package contains utility classes for generating configuration texts.
net.sf.ehcache.config.generator.model - package net.sf.ehcache.config.generator.model
This package contains utility classes encapsulating ideas of Elements and Attributes.
net.sf.ehcache.config.generator.model.elements - package net.sf.ehcache.config.generator.model.elements
This package contains utility classes encapsulating ideas of Elements and Attributes from the ehcache.xsd
net.sf.ehcache.constructs - package net.sf.ehcache.constructs
The constructs package builds on top of the core ehcache classes to create implementations for common caching patterns.
net.sf.ehcache.constructs.blocking - package net.sf.ehcache.constructs.blocking
Doug Lea in his book Concurrent Programming in Java talks about concurrency support constructs.
net.sf.ehcache.constructs.classloader - package net.sf.ehcache.constructs.classloader
ClassLoader contstructs package
net.sf.ehcache.constructs.nonstop - package net.sf.ehcache.constructs.nonstop
Ehcache-nonstopcache package
net.sf.ehcache.constructs.nonstop.concurrency - package net.sf.ehcache.constructs.nonstop.concurrency
Nonstop feature related to concurrent package
net.sf.ehcache.constructs.nonstop.store - package net.sf.ehcache.constructs.nonstop.store
Ehcache-nonstopcache behaviors package
net.sf.ehcache.constructs.nonstop.util - package net.sf.ehcache.constructs.nonstop.util
Ehcache-nonstopcache utility package
net.sf.ehcache.constructs.web - package net.sf.ehcache.constructs.web
This package contains only a ShutdownListener, useful for shutting down CacheManager in web apps.
net.sf.ehcache.distribution - package net.sf.ehcache.distribution
This package is for cache replication.
net.sf.ehcache.event - package net.sf.ehcache.event
This package contains interfaces and classes for listening to events.
net.sf.ehcache.exceptionhandler - package net.sf.ehcache.exceptionhandler
This package is for exception handling.
net.sf.ehcache.extension - package net.sf.ehcache.extension
This package contains interfaces and classes for the cache extension mechanism.
net.sf.ehcache.hibernate - package net.sf.ehcache.hibernate
This package contains interfaces and classes for Hibernate3.1 and higher.
net.sf.ehcache.hibernate.ccs - package net.sf.ehcache.hibernate.ccs
This package contains EhCache specific CacheConcurrencyStrategy implementations.
net.sf.ehcache.hibernate.management.api - package net.sf.ehcache.hibernate.management.api
This package contains JMX related interfaces for Hibernate and ehcache statistics
net.sf.ehcache.hibernate.management.impl - package net.sf.ehcache.hibernate.management.impl
This package contains JMX related classes for Hibernate and ehcache statistics
net.sf.ehcache.hibernate.nonstop - package net.sf.ehcache.hibernate.nonstop
This package contains interfaces and classes for Hibernate related to Ehcache's nonstop feature.
net.sf.ehcache.hibernate.regions - package net.sf.ehcache.hibernate.regions
This package contains region implementations used in Hibernate 3.3 and higher.
net.sf.ehcache.hibernate.strategy - package net.sf.ehcache.hibernate.strategy
This package contains EhCache specific AccessStrategy implementations.
net.sf.ehcache.loader - package net.sf.ehcache.loader
This package contains a cache loaders and associated factories.
net.sf.ehcache.management - package net.sf.ehcache.management
This package contains JMX MBeans and implementations for management of ehcache.
net.sf.ehcache.management.provider - package net.sf.ehcache.management.provider
This package contains classes related to MBeanRegistrationProvider and its implementation.
net.sf.ehcache.management.sampled - package net.sf.ehcache.management.sampled
This package contains classes related to MBeans with Sampled Statistics.
net.sf.ehcache.pool - package net.sf.ehcache.pool
This package contains the interfaces concerning the resource pooling facilities.
net.sf.ehcache.pool.impl - package net.sf.ehcache.pool.impl
This package contains implementations of the resource pooling interfaces.
net.sf.ehcache.pool.sizeof - package net.sf.ehcache.pool.sizeof
This package contains the SizeOf implementations for the pooling in Ehcache.
net.sf.ehcache.pool.sizeof.annotations - package net.sf.ehcache.pool.sizeof.annotations
This package contains annotations to control SizeOf calculations for the pooling in Ehcache.
net.sf.ehcache.pool.sizeof.filter - package net.sf.ehcache.pool.sizeof.filter
This package contains the SizeOf filtering interface and implementations for the pooling in Ehcache.
net.sf.ehcache.search - package net.sf.ehcache.search
This package contains classes for ehcache core search API.
net.sf.ehcache.search.aggregator - package net.sf.ehcache.search.aggregator
This package contains classes for search aggregator functionality.
net.sf.ehcache.search.attribute - package net.sf.ehcache.search.attribute
This package contains classes for ehcache search attributes
net.sf.ehcache.search.expression - package net.sf.ehcache.search.expression
This package contains classes for search expression types (ie.
net.sf.ehcache.search.impl - package net.sf.ehcache.search.impl
This package contains an implementation for Results.
net.sf.ehcache.statistics - package net.sf.ehcache.statistics
This package contains classes related to LiveCacheStatistics and its implementation.
net.sf.ehcache.statistics.sampled - package net.sf.ehcache.statistics.sampled
This package contains classes related to SampledCacheStatistics and its implementation.
net.sf.ehcache.store - package net.sf.ehcache.store
Store package.
net.sf.ehcache.store.chm - package net.sf.ehcache.store.chm
CHM package.
net.sf.ehcache.store.compound - package net.sf.ehcache.store.compound
This package contains the main classes and interfaces for the new fully coherent combination disk and memory store for unclustered Ehcache.
net.sf.ehcache.store.disk - package net.sf.ehcache.store.disk
This package contains the disk store.
net.sf.ehcache.store.disk.ods - package net.sf.ehcache.store.disk.ods
This package contains the classes managing the on-disk structure of the disk store.
net.sf.ehcache.terracotta - package net.sf.ehcache.terracotta
This package contains the Terracotta integration functionalities.
net.sf.ehcache.transaction - package net.sf.ehcache.transaction
This package contains classes for controlling cache operations for transactional use.
net.sf.ehcache.transaction.local - package net.sf.ehcache.transaction.local
This package contains the local transactions subsystem.
net.sf.ehcache.transaction.manager - package net.sf.ehcache.transaction.manager
This package temporarily contains Bitronix stuff.
net.sf.ehcache.transaction.xa - package net.sf.ehcache.transaction.xa
This package contains the functionality to provide XA support to a transactional Cache.
net.sf.ehcache.transaction.xa.commands - package net.sf.ehcache.transaction.xa.commands
This package contains a representation of the queued commands which can be executed against a XA store.
net.sf.ehcache.transaction.xa.processor - package net.sf.ehcache.transaction.xa.processor
XAResource requests processor.
net.sf.ehcache.util - package net.sf.ehcache.util
Util package.
net.sf.ehcache.util.counter - package net.sf.ehcache.util.counter
This package contains utility classes for Counter
net.sf.ehcache.util.counter.sampled - package net.sf.ehcache.util.counter.sampled
This package contains utility classes for SampledCounter's
net.sf.ehcache.util.lang - package net.sf.ehcache.util.lang
 
net.sf.ehcache.util.ratestatistics - package net.sf.ehcache.util.ratestatistics
Contains rate monitoring statistics objects.
net.sf.ehcache.writer - package net.sf.ehcache.writer
This package contains the cache writer functionalities.
net.sf.ehcache.writer.writebehind - package net.sf.ehcache.writer.writebehind
This package contains the write behind functionalities.
net.sf.ehcache.writer.writebehind.operations - package net.sf.ehcache.writer.writebehind.operations
This package contains the operations for the write behind functionalities.
net.sf.ehcache.writer.writethrough - package net.sf.ehcache.writer.writethrough
This package contains the write through functionalities.
NET_SF_EHCACHE_CONFIGURATION_RESOURCE_NAME - Static variable in class net.sf.ehcache.hibernate.EhCacheProvider
Deprecated. The Hibernate system property specifying the location of the ehcache configuration file name.
NET_SF_EHCACHE_CONFIGURATION_RESOURCE_NAME - Static variable in class net.sf.ehcache.hibernate.SingletonEhCacheProvider
Deprecated. The Hibernate system property specifying the location of the ehcache configuration file name.
NET_SF_EHCACHE_DISABLED - Static variable in class net.sf.ehcache.Cache
System Property based method of disabling ehcache.
NET_SF_EHCACHE_USE_CLASSIC_LRU - Static variable in class net.sf.ehcache.Cache
System Property based method of selecting the LruMemoryStore in use up to ehcache 1.5.
newInstance() - Static method in class net.sf.ehcache.CacheManager
A factory method to create a CacheManager with default config, or return it if it exists.
newInstance(String) - Static method in class net.sf.ehcache.CacheManager
A factory method to create a CacheManager with a specified configuration.
newInstance(URL) - Static method in class net.sf.ehcache.CacheManager
A factory method to create a CacheManager from an URL.
newInstance(InputStream) - Static method in class net.sf.ehcache.CacheManager
A factory method to create a CacheManager from a java.io.InputStream.
newInstance(Configuration) - Static method in class net.sf.ehcache.CacheManager
A factory method to create a CacheManager from a net.sf.ehcache.config.Configuration.
newTabularDataInstance() - Static method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
newTabularDataInstance() - Static method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
newTabularDataInstance
newTabularDataInstance() - Static method in class net.sf.ehcache.hibernate.management.impl.EntityStats
newTabularDataInstance
newTabularDataInstance() - Static method in class net.sf.ehcache.hibernate.management.impl.QueryStats
newTabularDataInstance
newThread(Runnable) - Method in class net.sf.ehcache.constructs.nonstop.util.CountingThreadFactory
newThread(Runnable) - Method in class net.sf.ehcache.util.NamedThreadFactory
Returns a new thread using a name as specified by this factory
next() - Method in class net.sf.ehcache.util.AggregateIterator
next() - Static method in class net.sf.ehcache.util.Timestamper
Returns an increasing unique value based on the System.currentTimeMillis() with some additional reserved space for a counter.
nextTimestamp() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Gets the next timestamp;
nextTimestamp() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
NODE_COHERENT - Static variable in interface net.sf.ehcache.store.Store
nodeCoherent property
NodeAttribute - Interface in net.sf.ehcache.config.generator.model
Interface that abstracts the idea of an attribute.
NodeElement - Interface in net.sf.ehcache.config.generator.model
Interface that abstracts the idea of an element.
NodeElementVisitor - Interface in net.sf.ehcache.config.generator.model
Interface for visiting a NodeElement
nodeJoined(ClusterNode) - Method in interface net.sf.ehcache.cluster.ClusterTopologyListener
A node has joined the cluster
nodeLeft(ClusterNode) - Method in interface net.sf.ehcache.cluster.ClusterTopologyListener
A node has left the cluster
nonstop(NonstopConfiguration) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Set the NonstopConfiguration
NonstopAccessStrategyFactory - Class in net.sf.ehcache.hibernate.nonstop
Implementation of EhcacheAccessStrategyFactory that takes care of Nonstop cache exceptions using HibernateNonstopCacheExceptionHandler
NonstopAccessStrategyFactory(EhcacheAccessStrategyFactory) - Constructor for class net.sf.ehcache.hibernate.nonstop.NonstopAccessStrategyFactory
Constructor accepting the actual factory
NonstopActiveDelegateHolder - Interface in net.sf.ehcache.constructs.nonstop
Interface for resolving the active TerracottaStore, nonstop Executor Service, underlying CacheLockProvider, all of which can change on rejoin
NonstopAwareCollectionRegionAccessStrategy - Class in net.sf.ehcache.hibernate.nonstop
Implementation of CollectionRegionAccessStrategy that handles NonStopCacheException using HibernateNonstopCacheExceptionHandler
NonstopAwareCollectionRegionAccessStrategy(CollectionRegionAccessStrategy, HibernateNonstopCacheExceptionHandler) - Constructor for class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
Constructor accepting the actual CollectionRegionAccessStrategy and the HibernateNonstopCacheExceptionHandler
NonstopAwareEntityRegionAccessStrategy - Class in net.sf.ehcache.hibernate.nonstop
Implementation of EntityRegionAccessStrategy that handles NonStopCacheException using HibernateNonstopCacheExceptionHandler
NonstopAwareEntityRegionAccessStrategy(EntityRegionAccessStrategy, HibernateNonstopCacheExceptionHandler) - Constructor for class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
Constructor accepting the actual EntityRegionAccessStrategy and the HibernateNonstopCacheExceptionHandler
NonstopCacheEventListener - Class in net.sf.ehcache.event
A CacheEventListener implementation that uses nonstop feature
NonstopCacheEventListener(NonstopActiveDelegateHolder) - Constructor for class net.sf.ehcache.event.NonstopCacheEventListener
Public constructor
NonStopCacheException - Exception in net.sf.ehcache.constructs.nonstop
Exception type thrown for NonStopCache operations
NonStopCacheException() - Constructor for exception net.sf.ehcache.constructs.nonstop.NonStopCacheException
Default constructor
NonStopCacheException(String, Throwable) - Constructor for exception net.sf.ehcache.constructs.nonstop.NonStopCacheException
Constructor accepting a String message and a Throwable cause
NonStopCacheException(String) - Constructor for exception net.sf.ehcache.constructs.nonstop.NonStopCacheException
Constructor accepting a String message
NonStopCacheException(Throwable) - Constructor for exception net.sf.ehcache.constructs.nonstop.NonStopCacheException
Constructor accepting a Throwable cause
NonStopCacheKeySet - Class in net.sf.ehcache.constructs.nonstop.concurrency
implementation which does not block threads when the cluster goes down
NonStopCacheKeySet(NonstopActiveDelegateHolder, List) - Constructor for class net.sf.ehcache.constructs.nonstop.concurrency.NonStopCacheKeySet
Non stop store to iterate over key set
NonstopCacheLockProvider - Class in net.sf.ehcache.constructs.nonstop.concurrency
Class implementing CacheLockProvider with nonstop feature
NonstopCacheLockProvider(NonstopStore, NonstopActiveDelegateHolder, ExplicitLockingContextThreadLocal, NonstopConfiguration) - Constructor for class net.sf.ehcache.constructs.nonstop.concurrency.NonstopCacheLockProvider
Public constructor
NonstopConfiguration - Class in net.sf.ehcache.config
Configuration class of nonstop caches
NonstopConfiguration() - Constructor for class net.sf.ehcache.config.NonstopConfiguration
 
nonstopConfiguration - Variable in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
The NonstopConfiguration of the cache using this store
NonstopConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the NonstopConfiguration
NonstopConfigurationElement(NodeElement, NonstopConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.NonstopConfigurationElement
Constructor accepting the parent and the NonstopConfiguration
NonstopExecutorService - Interface in net.sf.ehcache.constructs.nonstop
 
NonstopExecutorServiceFactory - Interface in net.sf.ehcache.constructs.nonstop
Factory for NonstopExecutorService
NonstopExecutorServiceImpl - Class in net.sf.ehcache.constructs.nonstop
Class used by NonStopCache for executing tasks within a timeout limit.
NonstopExecutorServiceImpl(ThreadFactory) - Constructor for class net.sf.ehcache.constructs.nonstop.NonstopExecutorServiceImpl
Constructor accepting a ThreadFactory that will be used to create threads for the pool
NonstopStore - Interface in net.sf.ehcache.constructs.nonstop.store
Interface for nonstop feature
NonstopStoreImpl - Class in net.sf.ehcache.constructs.nonstop.store
A NonstopStore implementation which does not block threads when the cluster goes down.
NonstopStoreImpl(NonstopActiveDelegateHolder, CacheCluster, NonstopConfiguration, CacheConfiguration.TransactionalMode, TransactionManagerLookup) - Constructor for class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Constructor accepting the NonstopActiveDelegateHolder, CacheCluster and NonstopConfiguration
NonstopThreadPool - Class in net.sf.ehcache.constructs.nonstop
A thread pool that creates another thread pool per requesting thread.
NonstopThreadPool(ThreadFactory) - Constructor for class net.sf.ehcache.constructs.nonstop.NonstopThreadPool
Constructor accepting the threadFactory
NonstopTimeoutBehaviorFactory - Interface in net.sf.ehcache.constructs.nonstop
Factory for creating NonstopStore that will be used on timeout.
NonstopTimeoutBehaviorStoreResolver - Interface in net.sf.ehcache.constructs.nonstop.store
Interface for resolving a NonstopStore.
NonStrictReadWriteEhcacheCollectionRegionAccessStrategy - Class in net.sf.ehcache.hibernate.strategy
Ehcache specific non-strict read/write collection region access strategy
NonStrictReadWriteEhcacheCollectionRegionAccessStrategy(EhcacheCollectionRegion, Settings) - Constructor for class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheCollectionRegionAccessStrategy
Create a non-strict read/write access strategy accessing the given collection region.
NonStrictReadWriteEhcacheEntityRegionAccessStrategy - Class in net.sf.ehcache.hibernate.strategy
Ehcache specific non-strict read/write entity region access strategy
NonStrictReadWriteEhcacheEntityRegionAccessStrategy(EhcacheEntityRegion, Settings) - Constructor for class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
Create a non-strict read/write access strategy accessing the given collection region.
NOOP_TYPE_NAME - Static variable in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Type name for TimeoutBehaviorConfiguration.TimeoutBehaviorType.NOOP
NoopCacheCluster - Class in net.sf.ehcache.cluster
This is a dummy implementation of the CacheCluster (Null Object Pattern).
NoopCacheCluster() - Constructor for class net.sf.ehcache.cluster.NoopCacheCluster
 
NoOpOnTimeoutStore - Class in net.sf.ehcache.constructs.nonstop.store
Implementation of NonstopStore which returns null for all get operations and does nothing for puts and removes.
not() - Method in class net.sf.ehcache.search.expression.BaseCriteria
Produce a criteria that is the boolean "not" of this
not() - Method in interface net.sf.ehcache.search.expression.Criteria
Produce a criteria that is the boolean "not" of this
Not - Class in net.sf.ehcache.search.expression
A search criteria composed of the logical "not" (ie.
Not(Criteria) - Constructor for class net.sf.ehcache.search.expression.Not
Construct a "not" criteria of the given criteria
notAlive() - Method in interface net.sf.ehcache.distribution.CacheReplicator
Returns whether the replicator is not active.
notAlive() - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Asserts that the replicator is active.
NotEqualTo - Class in net.sf.ehcache.search.expression
Criteria for plain "not equals to" condition
NotEqualTo(String, Object) - Constructor for class net.sf.ehcache.search.expression.NotEqualTo
Constructor
NotificationScope - Enum in net.sf.ehcache.event
This enumeration defines valid values for event listener notification scope.
notifyCacheAdded(String) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Called immediately after a cache has been added and activated.
notifyCacheAdded(String) - Method in interface net.sf.ehcache.event.CacheManagerEventListener
Called immediately after a cache has been added and activated.
notifyCacheAdded(String) - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Called immediately after a cache has been added and activated.
notifyCacheAdded(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistrationImpl
No-op in this case
notifyCacheAdded(String) - Method in class net.sf.ehcache.management.ManagementService
Called immediately after a cache has been added and activated.
notifyCacheAdded(String) - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Called immediately after a cache has been added and activated.
notifyCacheElementEvicted() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when an element is expired in the cache
notifyCacheElementEvicted() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when an element is expired in the cache
notifyCacheElementEvicted() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when an element is expired in the cache
notifyCacheElementEvicted() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when an element is expired in the cache
notifyCacheElementExpired() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when an element in the cache expires
notifyCacheElementExpired() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when an element in the cache expires
notifyCacheElementExpired() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when an element in the cache expires
notifyCacheElementExpired() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when an element in the cache expires
notifyCacheElementPut() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when an element is inserted in the cache
notifyCacheElementPut() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when an element is inserted in the cache
notifyCacheElementPut() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when an element is inserted in the cache
notifyCacheElementPut() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when an element is inserted in the cache
notifyCacheElementRemoved() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when an element is removed from the cache
notifyCacheElementRemoved() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when an element is removed from the cache
notifyCacheElementRemoved() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when an element is removed from the cache
notifyCacheElementRemoved() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when an element is removed from the cache
notifyCacheElementUpdated() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when an element is updated in the cache, i.e.
notifyCacheElementUpdated() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when an element is updated in the cache, i.e.
notifyCacheElementUpdated() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when an element is updated in the cache, i.e.
notifyCacheElementUpdated() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when an element is updated in the cache, i.e.
notifyCacheHitInMemory() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called on a cache hit in the MemoryStore
notifyCacheHitInMemory() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called on a cache hit in the MemoryStore
notifyCacheHitInMemory() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called on a cache hit in the MemoryStore
notifyCacheHitInMemory() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called on a cache hit in the MemoryStore
notifyCacheHitOffHeap() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called on a cache hit in the off-heap store
notifyCacheHitOffHeap() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called on a cache hit in the off-heap store
notifyCacheHitOffHeap() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called on a cache hit in the off-heap store
notifyCacheHitOffHeap() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called on a cache hit in the off-heap store
notifyCacheHitOnDisk() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called on a cache hit in the DiskStore
notifyCacheHitOnDisk() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called on a cache hit in the DiskStore
notifyCacheHitOnDisk() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called on a cache hit in the DiskStore
notifyCacheHitOnDisk() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called on a cache hit in the DiskStore
notifyCacheMissedWithExpired() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when an element is found in the cache but already expired
notifyCacheMissedWithExpired() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when an element is found in the cache but already expired
notifyCacheMissedWithExpired() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when an element is found in the cache but already expired
notifyCacheMissedWithExpired() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when an element is found in the cache but already expired
notifyCacheMissedWithNotFound() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when an element is not found in the cache
notifyCacheMissedWithNotFound() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when an element is not found in the cache
notifyCacheMissedWithNotFound() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when an element is not found in the cache
notifyCacheMissedWithNotFound() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when an element is not found in the cache
notifyCacheMissInMemory() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called on a cache miss in the MemoryStore
notifyCacheMissInMemory() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called on a cache miss in the MemoryStore
notifyCacheMissInMemory() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called on a cache miss in the MemoryStore
notifyCacheMissInMemory() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called on a cache miss in the MemoryStore
notifyCacheMissOffHeap() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called on a cache miss in the off-heap store
notifyCacheMissOffHeap() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called on a cache miss in the off-heap store
notifyCacheMissOffHeap() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called on a cache miss in the off-heap store
notifyCacheMissOffHeap() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called on a cache miss in the off-heap store
notifyCacheMissOnDisk() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called on a cache miss in the DiskStore
notifyCacheMissOnDisk() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called on a cache miss in the DiskStore
notifyCacheMissOnDisk() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called on a cache miss in the DiskStore
notifyCacheMissOnDisk() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called on a cache miss in the DiskStore
notifyCacheRemoved(String) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Called immediately after a cache has been disposed and removed.
notifyCacheRemoved(String) - Method in interface net.sf.ehcache.event.CacheManagerEventListener
Called immediately after a cache has been disposed and removed.
notifyCacheRemoved(String) - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Called immediately after a cache has been disposed and removed.
notifyCacheRemoved(String) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistrationImpl
No-op in this case
notifyCacheRemoved(String) - Method in class net.sf.ehcache.management.ManagementService
Called immediately after a cache has been disposed and removed.
notifyCacheRemoved(String) - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Called immediately after a cache has been disposed and removed.
notifyCacheSearch(long) - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when a search finishes execution
notifyCacheSearch(long) - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when a search finishes execution
notifyCacheSearch(long) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when a search finishes execution
notifyCacheSearch(long) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when a search finishes execution
notifyDirectEviction(Element) - Method in class net.sf.ehcache.store.MemoryStore
Called when an element is evicted even before it could be installed inside the store
notifyDirectEviction(Element) - Method in class net.sf.ehcache.store.NotifyingMemoryStore
Called when an element is evicted even before it could be installed inside the store
notifyElementEvicted(Ehcache, Element) - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Called immediately after an element is evicted from the cache.
notifyElementEvicted(Ehcache, Element) - Method in interface net.sf.ehcache.event.CacheEventListener
Called immediately after an element is evicted from the cache.
notifyElementEvicted(Ehcache, Element) - Method in class net.sf.ehcache.event.CacheEventListenerAdapter
Called immediately after an element is evicted from the cache.
notifyElementEvicted(Ehcache, Element) - Method in class net.sf.ehcache.event.NonstopCacheEventListener
Called immediately after an element is evicted from the cache.
notifyElementEvicted(Element, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element has been evicted from the cache
notifyElementEvicted(RegisteredEventListeners.ElementCreationCallback, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element has been evicted from the cache
notifyElementEvicted(Ehcache, Element) - Method in class net.sf.ehcache.event.TerracottaCacheEventReplication
Called immediately after an element is evicted from the cache.
notifyElementEvicted(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called immediately after an element is evicted from the cache.
notifyElementEvicted(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called immediately after an element is evicted from the cache.
notifyElementEvicted(Ehcache, Element) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called immediately after an element is evicted from the cache.
notifyElementExpired(Ehcache, Element) - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Called immediately after an element is found to be expired.
notifyElementExpired(Ehcache, Element) - Method in interface net.sf.ehcache.event.CacheEventListener
Called immediately after an element is found to be expired.
notifyElementExpired(Ehcache, Element) - Method in class net.sf.ehcache.event.CacheEventListenerAdapter
Called immediately after an element is found to be expired.
notifyElementExpired(Ehcache, Element) - Method in class net.sf.ehcache.event.NonstopCacheEventListener
Called immediately after an element is found to be expired.
notifyElementExpired(Ehcache, Element) - Method in class net.sf.ehcache.event.TerracottaCacheEventReplication
Called immediately after an element is found to be expired.
notifyElementExpired(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called immediately after an element is found to be expired.
notifyElementExpired(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called immediately after an element is found to be expired.
notifyElementExpired(Ehcache, Element) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called immediately after an element is found to be expired.
notifyElementExpiry(Element, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element has expired
notifyElementExpiry(RegisteredEventListeners.ElementCreationCallback, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element has expired
notifyElementPut(Ehcache, Element) - Method in class net.sf.ehcache.distribution.RMIAsynchronousCacheReplicator
Called immediately after an element has been put into the cache.
notifyElementPut(Ehcache, Element) - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Called immediately after an element has been put into the cache.
notifyElementPut(Ehcache, Element) - Method in interface net.sf.ehcache.event.CacheEventListener
Called immediately after an element has been put into the cache.
notifyElementPut(Ehcache, Element) - Method in class net.sf.ehcache.event.CacheEventListenerAdapter
Called immediately after an element has been put into the cache.
notifyElementPut(Ehcache, Element) - Method in class net.sf.ehcache.event.NonstopCacheEventListener
Called immediately after an element has been put into the cache.
notifyElementPut(Element, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element was put into the cache
notifyElementPut(RegisteredEventListeners.ElementCreationCallback, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element was put into the cache
notifyElementPut(Ehcache, Element) - Method in class net.sf.ehcache.event.TerracottaCacheEventReplication
Called immediately after an element has been put into the cache.
notifyElementPut(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called immediately after an element has been put into the cache.
notifyElementPut(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called immediately after an element has been put into the cache.
notifyElementPut(Ehcache, Element) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called immediately after an element has been put into the cache.
notifyElementRemoved(Ehcache, Element) - Method in class net.sf.ehcache.distribution.RMIAsynchronousCacheReplicator
Called immediately after an attempt to remove an element.
notifyElementRemoved(Ehcache, Element) - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Called immediately after an attempt to remove an element.
notifyElementRemoved(Ehcache, Element) - Method in interface net.sf.ehcache.event.CacheEventListener
Called immediately after an attempt to remove an element.
notifyElementRemoved(Ehcache, Element) - Method in class net.sf.ehcache.event.CacheEventListenerAdapter
Called immediately after an attempt to remove an element.
notifyElementRemoved(Ehcache, Element) - Method in class net.sf.ehcache.event.NonstopCacheEventListener
Called immediately after an attempt to remove an element.
notifyElementRemoved(Element, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element was removed
notifyElementRemoved(RegisteredEventListeners.ElementCreationCallback, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element was removed
notifyElementRemoved(Ehcache, Element) - Method in class net.sf.ehcache.event.TerracottaCacheEventReplication
Called immediately after an attempt to remove an element.
notifyElementRemoved(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called immediately after an attempt to remove an element.
notifyElementRemoved(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called immediately after an attempt to remove an element.
notifyElementRemoved(Ehcache, Element) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called immediately after an attempt to remove an element.
notifyElementUpdated(Ehcache, Element) - Method in class net.sf.ehcache.distribution.RMIAsynchronousCacheReplicator
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyElementUpdated(Ehcache, Element) - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyElementUpdated(Ehcache, Element) - Method in interface net.sf.ehcache.event.CacheEventListener
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyElementUpdated(Ehcache, Element) - Method in class net.sf.ehcache.event.CacheEventListenerAdapter
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyElementUpdated(Ehcache, Element) - Method in class net.sf.ehcache.event.NonstopCacheEventListener
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyElementUpdated(Element, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element in the cache was updated
notifyElementUpdated(RegisteredEventListeners.ElementCreationCallback, boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that an element in the cache was updated
notifyElementUpdated(Ehcache, Element) - Method in class net.sf.ehcache.event.TerracottaCacheEventReplication
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyElementUpdated(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyElementUpdated(Ehcache, Element) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyElementUpdated(Ehcache, Element) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called immediately after an element has been put into the cache and the element already existed in the cache.
notifyEvictionFromCache(Serializable) - Method in class net.sf.ehcache.store.DiskBackedMemoryStore
Whether evicting this from the cache should fire when evicting from upper tiers
notifyEvictionFromCache(Serializable) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Whether evicting this from the cache should fire when evicting from upper tiers
notifyExpiry(Element) - Method in class net.sf.ehcache.store.LruMemoryStore
Before eviction elements are checked.
NotifyingMemoryStore - Class in net.sf.ehcache.store
 
notifyListenersOnException(boolean) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
notifyRemoveAll(Ehcache) - Method in class net.sf.ehcache.distribution.RMIAsynchronousCacheReplicator
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll(Ehcache) - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll(Ehcache) - Method in interface net.sf.ehcache.event.CacheEventListener
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll(Ehcache) - Method in class net.sf.ehcache.event.CacheEventListenerAdapter
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll(Ehcache) - Method in class net.sf.ehcache.event.NonstopCacheEventListener
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll(boolean) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Notifies all registered listeners, in no guaranteed order, that removeAll has been called and all elements cleared
notifyRemoveAll(Ehcache) - Method in class net.sf.ehcache.event.TerracottaCacheEventReplication
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when Cache.removeAll() is called
notifyRemoveAll(Ehcache) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll(Ehcache) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll(Ehcache) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called during Ehcache.removeAll() to indicate that the all elements have been removed from the cache in a bulk operation.
notifyRemoveAll() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when Cache.removeAll() is called
notifyRemoveAll() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when Cache.removeAll() is called
notifyRemoveAll() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when Cache.removeAll() is called
notifyStatisticsAccuracyChanged(int) - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Notified when the statistics accuracy is changed.
notifyStatisticsAccuracyChanged(int) - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Notified when the statistics accuracy is changed.
notifyStatisticsAccuracyChanged(int) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Notified when the statistics accuracy is changed.
notifyStatisticsAccuracyChanged(int) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Notified when the statistics accuracy is changed.
notifyStatisticsCleared() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when statistics is cleared
notifyStatisticsCleared() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when statistics is cleared
notifyStatisticsCleared() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when statistics is cleared
notifyStatisticsCleared() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when statistics is cleared
notifyStatisticsEnabledChanged(boolean) - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when statistics is enabled/disabled
notifyStatisticsEnabledChanged(boolean) - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when statistics is enabled/disabled
notifyStatisticsEnabledChanged(boolean) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when statistics is enabled/disabled
notifyStatisticsEnabledChanged(boolean) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when statistics is enabled/disabled
notifyTimeTakenForGet(long) - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Notified with time taken for a get operation in the cache
notifyTimeTakenForGet(long) - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Notified with time taken for a get operation in the cache
notifyTimeTakenForGet(long) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Notified with time taken for a get operation in the cache
notifyTimeTakenForGet(long) - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Notified with time taken for a get operation in the cache
notifyXaCommit() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when the Cache's XAResource has been asked to commit
notifyXaCommit() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when the Cache's XAResource has been asked to commit
notifyXaCommit() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when the Cache's XAResource has been asked to commit
notifyXaCommit() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when the Cache's XAResource has been asked to commit
notifyXaRollback() - Method in interface net.sf.ehcache.statistics.CacheUsageListener
Called when the Cache's XAResource has been asked to rollback
notifyXaRollback() - Method in class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
Called when the Cache's XAResource has been asked to rollback
notifyXaRollback() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Called when the Cache's XAResource has been asked to rollback
notifyXaRollback() - Method in class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Called when the Cache's XAResource has been asked to rollback
NullHibernateStats - Class in net.sf.ehcache.hibernate.management.impl
Implementation of HibernateStats that does nothing

NullLiveCacheStatisticsData - Class in net.sf.ehcache.statistics
A no-op implementation which can be used both as a LiveCacheStatistics and LiveCacheStatisticsData
NullLiveCacheStatisticsData() - Constructor for class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
 
NullMBeanRegistrationProvider - Class in net.sf.ehcache.management.provider
A Null implementation of MBeanRegistrationProvider which does nothing

NullMBeanRegistrationProvider() - Constructor for class net.sf.ehcache.management.provider.NullMBeanRegistrationProvider
 
NullReadWriteCopyStrategy - Class in net.sf.ehcache.store.compound
No-op copy strategy
NullReadWriteCopyStrategy() - Constructor for class net.sf.ehcache.store.compound.NullReadWriteCopyStrategy
 
NullResults - Class in net.sf.ehcache.search
An empty result instance
NullResults() - Constructor for class net.sf.ehcache.search.NullResults
 
NullSampledCacheStatistics - Class in net.sf.ehcache.statistics.sampled
A no-op implementation of SampledCacheStatistics

NullSampledCacheStatistics() - Constructor for class net.sf.ehcache.statistics.sampled.NullSampledCacheStatistics
 
NullStore - Class in net.sf.ehcache.store
A store implementation which does not store anything.
numberOfCachesThatAreDiskPersistent() - Method in class net.sf.ehcache.config.ConfigurationHelper
Calculates the number of caches in the configuration that are diskPersistent
numberOfCachesThatOverflowToDisk() - Method in class net.sf.ehcache.config.ConfigurationHelper
Calculates the number of caches in the configuration that overflow to disk

O

ObjectExistsException - Exception in net.sf.ehcache
Thrown when a duplicate cache is attemtpted to be created
ObjectExistsException() - Constructor for exception net.sf.ehcache.ObjectExistsException
Constructor for the ObjectExistsException object.
ObjectExistsException(String) - Constructor for exception net.sf.ehcache.ObjectExistsException
Constructor for the ObjectExistsException object.
OFF_HEAP_STORE_CLASSNAME - Static variable in class net.sf.ehcache.Cache
The FQCN for offheap stores
ON_HEAP_THRESHOLD - Static variable in class net.sf.ehcache.CacheManager
Threshold, in percent of the available heap, above which the CacheManager will warn if the configured memory
ONE_CENTURY - Static variable in interface net.sf.ehcache.concurrent.Sync
One century in milliseconds; convenient as a time-out value
ONE_DAY - Static variable in interface net.sf.ehcache.concurrent.Sync
One day, in milliseconds; convenient as a time-out value *
ONE_HOUR - Static variable in interface net.sf.ehcache.concurrent.Sync
One hour, in milliseconds; convenient as a time-out value *
ONE_HUNDRED_MB - Static variable in class net.sf.ehcache.distribution.RMIBootstrapCacheLoaderFactory
The highest reasonable chunk size in bytes
ONE_MINUTE - Static variable in interface net.sf.ehcache.concurrent.Sync
One minute, in milliseconds; convenient as a time-out value *
ONE_MS - Static variable in class net.sf.ehcache.util.Timestamper
What is one milliseconds, based on "counter value reserved space", for this Timestamper
ONE_SECOND - Static variable in interface net.sf.ehcache.concurrent.Sync
One second, in milliseconds; convenient as a time-out value *
ONE_WEEK - Static variable in interface net.sf.ehcache.concurrent.Sync
One week, in milliseconds; convenient as a time-out value *
ONE_YEAR - Static variable in interface net.sf.ehcache.concurrent.Sync
One year in milliseconds; convenient as a time-out value Not that it matters, but there is some variation across standard sources about value at msec precision.
onException(Ehcache, Object, Exception) - Method in interface net.sf.ehcache.exceptionhandler.CacheExceptionHandler
Called if an Exception occurs in a Cache method.
onHeapSize - Variable in class net.sf.ehcache.store.disk.DiskStorageFactory.DiskSubstitute
Cached size of this mapping on the Java heap.
OperationConverter<T> - Interface in net.sf.ehcache.writer.writebehind
Interface that allows an converter to be implemented that can create an operation based on an arbitrary object.
OperationsFilter<T> - Interface in net.sf.ehcache.writer.writebehind
An interface for implementing a filter for operations before they are processed.
optimisticFailureCount - Variable in class net.sf.ehcache.hibernate.management.impl.EntityStats
optimisticFailureCount
OptimisticLockFailureException - Exception in net.sf.ehcache.transaction.xa
This exception is used internally when an optimistic lock failed, ie: when the expected previous value is not found at commit time.
OptimisticLockFailureException() - Constructor for exception net.sf.ehcache.transaction.xa.OptimisticLockFailureException
Constructor
optional - Variable in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Whether this element is optional
optional(boolean) - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Builder convenience method for setting optional
optional(boolean) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Builder convenience method for setting optional
or(Criteria) - Method in class net.sf.ehcache.search.expression.AlwaysMatch
Produce a criteria that is the boolean "or" of this and the given other criteria
or(Criteria) - Method in class net.sf.ehcache.search.expression.BaseCriteria
Produce a criteria that is the boolean "or" of this and the given other criteria
or(Criteria) - Method in interface net.sf.ehcache.search.expression.Criteria
Produce a criteria that is the boolean "or" of this and the given other criteria
Or - Class in net.sf.ehcache.search.expression
A search criteria composed of the logical "or" of two or more other criteria
Or(Criteria, Criteria) - Constructor for class net.sf.ehcache.search.expression.Or
Simple constructor for two criteria
or(Criteria) - Method in class net.sf.ehcache.search.expression.Or
Produce a criteria that is the boolean "or" of this and the given other criteria
OrderComparator - Class in net.sf.ehcache.search.impl
Compound sort ordering comparactor
OrderComparator(List<StoreQuery.Ordering>) - Constructor for class net.sf.ehcache.search.impl.OrderComparator
Constructor
orphanEviction(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
orphanEvictionPeriod(int) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
overflowToDisk - Variable in class net.sf.ehcache.config.CacheConfiguration
whether elements can overflow to disk when the in-memory cache has reached the set limit.
overflowToDisk(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets whether elements can overflow to disk when the in-memory cache has reached the set limit.
overflowToOffHeap - Variable in class net.sf.ehcache.config.CacheConfiguration
whether elements can overflow to off heap memory when the in-memory cache has reached the set limit.
overflowToOffHeap(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder to enable or disable offheap store for the cache.
OverrideCheck - Class in net.sf.ehcache.constructs.nonstop.util
A utility class to check whether one class overrides all methods of its superclass or an interface that it implements

P

parent - Variable in class net.sf.ehcache.config.generator.model.AbstractNodeElement
The parent
parse(String) - Static method in class net.sf.ehcache.util.MemorySizeParser
Parse a String containing a human-readable memory size.
parseAmount(String) - Static method in enum net.sf.ehcache.config.MemoryUnit
Parses the amount represented by the string, without caring for the unit
parseBoolean(String) - Static method in class net.sf.ehcache.util.PropertyUtil
Null safe, parser of boolean from a String
parseConfiguration(File) - Static method in class net.sf.ehcache.config.ConfigurationFactory
Configures a bean from an XML file.
parseConfiguration(URL) - Static method in class net.sf.ehcache.config.ConfigurationFactory
Configures a bean from an XML file available as an URL.
parseConfiguration() - Static method in class net.sf.ehcache.config.ConfigurationFactory
Configures a bean from an XML file in the classpath.
parseConfiguration(InputStream) - Static method in class net.sf.ehcache.config.ConfigurationFactory
Configures a bean from an XML input stream.
parseProperties(String, String) - Static method in class net.sf.ehcache.util.PropertyUtil
Parse properties supplied as a comma separated list into a Properties object
parseSizeInBytes(String) - Static method in enum net.sf.ehcache.config.MemoryUnit
Parses the string for its content, returning the represented value in bytes
parseUnit(String) - Static method in enum net.sf.ehcache.config.MemoryUnit
Parses the unit part of a String, if no unit char available, returns MemoryUnit.BYTES
PassThroughFilter - Class in net.sf.ehcache.pool.sizeof.filter
Filter that doesn't filter!
PassThroughFilter() - Constructor for class net.sf.ehcache.pool.sizeof.filter.PassThroughFilter
 
path(String) - Method in class net.sf.ehcache.config.DiskStoreConfiguration
Builder method to set the disk store path, see DiskStoreConfiguration.setPath(String)
peek() - Method in class net.sf.ehcache.util.CircularLossyQueue
Returns value at the tail of the queue
peerUrls - Variable in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
Contains a RMI URLs of the form: "//" + hostName + ":" + port + "/" + cacheName;
performBatchOperation(CacheWriter) - Method in interface net.sf.ehcache.writer.writebehind.operations.BatchOperation
Perform the batch operation for a particular batch writer
performBatchOperation(CacheWriter) - Method in class net.sf.ehcache.writer.writebehind.operations.DeleteAllOperation
Perform the batch operation for a particular batch writer
performBatchOperation(CacheWriter) - Method in class net.sf.ehcache.writer.writebehind.operations.WriteAllOperation
Perform the batch operation for a particular batch writer
performClusterOperation() - Method in interface net.sf.ehcache.constructs.nonstop.ClusterOperation
Perform the actual operation.
performClusterOperationTimedOut(TimeoutBehaviorConfiguration.TimeoutBehaviorType) - Method in interface net.sf.ehcache.constructs.nonstop.ClusterOperation
Perform action when the actual operation is not able to complete.
performSingleOperation(CacheWriter) - Method in class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Perform this operation as a single execution with the provided cache writer
performSingleOperation(CacheWriter) - Method in interface net.sf.ehcache.writer.writebehind.operations.SingleOperation
Perform this operation as a single execution with the provided cache writer
performSingleOperation(CacheWriter) - Method in class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Perform this operation as a single execution with the provided cache writer
pinnedKeySet() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
pinnedSize() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
pinning(PinningConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
 
pinningConfiguration - Variable in class net.sf.ehcache.config.CacheConfiguration
The PinningConfiguration.
PinningConfiguration - Class in net.sf.ehcache.config
Class to hold the Pinning configuration.
PinningConfiguration() - Constructor for class net.sf.ehcache.config.PinningConfiguration
 
PinningConfiguration.Store - Enum in net.sf.ehcache.config
Possible store values
PinningConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the PinningConfiguration
PinningConfigurationElement(NodeElement, PinningConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.PinningConfigurationElement
Constructor accepting the parent and the TerracottaConfiguration
Policy - Interface in net.sf.ehcache.store
An eviction policy.
poll() - Method in class net.sf.ehcache.util.lang.VicariousThreadLocal
Check if any strong references need should be removed due to thread exit.
Pool<T> - Interface in net.sf.ehcache.pool
Pools are used to track shared resource consumption.
PoolableStore - Interface in net.sf.ehcache.pool
A poolable store reports its resource usage to a Pool.
PoolAccessor<T> - Interface in net.sf.ehcache.pool
PoolAccessors are used by stores to tell the pools about their resource consumption
PoolEvictor<T> - Interface in net.sf.ehcache.pool
PoolEvictors are responsible for finding the best candidates in a collection of resources using a shared resource pool and performing eviction on them.
populateListOfRemoteCachePeers() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Should be called on init because this is one of the last things that should happen on CacheManager startup.
port - Variable in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
The RMI listener port
PreferTCCLObjectInputStream - Class in net.sf.ehcache.util
ObjectInputStream that first uses the thread context classloader (TCCL) when resolving classes with fallback to the regular rerializtion loader semantics (which will use this class's loader to resolve classes)
PreferTCCLObjectInputStream(InputStream) - Constructor for class net.sf.ehcache.util.PreferTCCLObjectInputStream
Constructor
prepare(Store, SoftLockFactory, XidTransactionID, ElementValueComparator) - Method in class net.sf.ehcache.transaction.xa.commands.AbstractStoreCommand
Prepare the commmand un the underlying store
prepare(Store, SoftLockFactory, XidTransactionID, ElementValueComparator) - Method in interface net.sf.ehcache.transaction.xa.commands.Command
Prepare the commmand un the underlying store
prepare(Xid) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
prepareInternal(Xid) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
The prepare implementation
PRINT_STACK_TRACE_ON_EXCEPTION_PROPERTY - Static variable in interface net.sf.ehcache.constructs.nonstop.NonstopExecutorService
System property name which if set to true prints stack trace of nonstop thread upon exception
process(XARequest) - Method in class net.sf.ehcache.transaction.xa.processor.XARequestProcessor
Process a XARequest
ProductInfo - Class in net.sf.ehcache.util
Build properties of the product
ProductInfo() - Constructor for class net.sf.ehcache.util.ProductInfo
Construct a default product info
ProductInfo(String) - Constructor for class net.sf.ehcache.util.ProductInfo
Construct product info object from a resource name
ProductInfo(InputStream) - Constructor for class net.sf.ehcache.util.ProductInfo
Construct product info object from a resource input stream
properties - Variable in class net.sf.ehcache.config.FactoryConfiguration
properties.
properties(String) - Method in class net.sf.ehcache.config.FactoryConfiguration
 
properties(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the extractor properties
properties(String) - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Set the properties
propertyChange(PropertyChangeEvent) - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
Handles changes to the Configuration this RuntimeCfg backs
propertyChange(PropertyChangeEvent) - Method in class net.sf.ehcache.management.sampled.SampledCache
 
propertySeparator - Variable in class net.sf.ehcache.config.FactoryConfiguration
A property separator.
propertySeparator(String) - Method in class net.sf.ehcache.config.FactoryConfiguration
 
propertySeparator(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the extractor properties separator
propertySeparator(String) - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Set the property separator
PropertyUtil - Class in net.sf.ehcache.util
Property utilities.
ProviderMBeanRegistrationHelper - Class in net.sf.ehcache.hibernate.management.impl
Helper class for registering mbeans for ehcache backed hibernate second level cache

ProviderMBeanRegistrationHelper() - Constructor for class net.sf.ehcache.hibernate.management.impl.ProviderMBeanRegistrationHelper
 
purge() - Method in class net.sf.ehcache.util.FailSafeTimer
If the runtime environment restricts thread creation, this method does nothing.
push(T) - Method in class net.sf.ehcache.util.CircularLossyQueue
Adds a new item
put(Element) - Method in class net.sf.ehcache.Cache
Put an element in the cache.
put(Element, boolean) - Method in class net.sf.ehcache.Cache
Put an element in the cache.
put(Element) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Adds an entry and unlocks it
put(Element) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Put an element in the cache.
put(Element, boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Put an element in the cache.
put(Element, boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Put an element in the cache.
put(Element) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Put an element in the cache.
put(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Puts an item into the store.
put(Element) - Method in interface net.sf.ehcache.distribution.CachePeer
Put an element in the cache.
PUT - Static variable in class net.sf.ehcache.distribution.LegacyEventMessage
A put or update event.
put(Element) - Method in class net.sf.ehcache.distribution.RMICachePeer
Puts an Element into the underlying cache without notifying listeners or updating statistics.
put(Element) - Method in class net.sf.ehcache.distribution.TransactionalRMICachePeer
 
put(Element) - Method in interface net.sf.ehcache.Ehcache
Put an element in the cache.
put(Element, boolean) - Method in interface net.sf.ehcache.Ehcache
Put an element in the cache.
put(Object, Object, long, Object, Comparator, boolean) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. 
put(Object, Object, long, Object, Comparator, boolean) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. 
put(Object, Object, long, Object, Comparator, boolean) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. 
put(Object, Object) - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Puts an object into the cache.
put(Object, Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Map the given value to the given key, replacing any existing mapping for this key this unpins the key in the cache should it be currently pinned
put(Object, Element) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
put(Object, Element, long) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
put(Element) - Method in class net.sf.ehcache.store.disk.DiskStore
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.store.LruMemoryStore
Puts an item in the cache.
put(Object, Object) - Method in class net.sf.ehcache.store.LruMemoryStore.SpoolingLinkedHashMap
put(Element) - Method in class net.sf.ehcache.store.MemoryStore
Puts an item in the store.
put(Element) - Method in class net.sf.ehcache.store.NullStore
Puts an item into the store.
put(Element) - Method in interface net.sf.ehcache.store.Store
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Puts an item into the store.
put(Element) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Puts an item into the store.
put(K, V) - Method in class net.sf.ehcache.util.WeakIdentityConcurrentMap
Puts into the underlying
put(Element) - Method in interface net.sf.ehcache.writer.CacheWriterManager
Schedule a put operation for this element in the CacheWriterManager, which will call the CacheWriter when appropriate.
put(Element) - Method in class net.sf.ehcache.writer.writebehind.WriteBehindManager
Schedule a put operation for this element in the CacheWriterManager, which will call the CacheWriter when appropriate.
put(Element) - Method in class net.sf.ehcache.writer.writethrough.WriteThroughManager
Schedule a put operation for this element in the CacheWriterManager, which will call the CacheWriter when appropriate.
PUT_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
PUT_COLOR
PUT_DRAW_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
PUT_DRAW_COLOR
PUT_FILL_COLOR - Static variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionUtils
PUT_FILL_COLOR
putAll(Collection<Element>) - Method in class net.sf.ehcache.Cache
Puts a collection of elements in the cache.
putAll(Collection) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Puts a collection of elements in the cache.
putAll(Collection<Element>) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Puts a collection of elements in the cache.
putAll(Collection<Element>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Puts a collection of elements into the store.
putAll(Collection<Element>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Puts a collection of elements into the store.
putAll(Collection<Element>) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Puts a collection of elements into the store.
putAll(Collection<Element>) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Puts a collection of elements into the store.
putAll(Collection<Element>) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Puts a collection of elements into the store.
putAll(Collection<Element>) - Method in interface net.sf.ehcache.Ehcache
Puts a collection of elements in the cache.
putAll(Collection<Element>) - Method in class net.sf.ehcache.store.AbstractStore
Puts a collection of elements into the store.
putAll(Collection<Element>) - Method in interface net.sf.ehcache.store.Store
Puts a collection of elements into the store.
putAll(Collection<Element>) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Puts a collection of elements into the store.
putCount - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
put count
putFromLoad(Object, Object, long, Object, boolean) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
putFromLoad(Object, Object, long, Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
putFromLoad(Object, Object, long, Object, boolean) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
putFromLoad(Object, Object, long, Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
putFromLoad(Object, Object, long, Object, boolean) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheCollectionRegionAccessStrategy
This method is a placeholder for method signatures supplied by interfaces pulled in further down the class hierarchy.
putFromLoad(Object, Object, long, Object, boolean) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
This method is a placeholder for method signatures supplied by interfaces pulled in further down the class hierarchy.
putFromLoad(Object, Object, long, Object, boolean) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheCollectionRegionAccessStrategy
This method is a placeholder for method signatures supplied by interfaces pulled in further down the class hierarchy.
putFromLoad(Object, Object, long, Object, boolean) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
This method is a placeholder for method signatures supplied by interfaces pulled in further down the class hierarchy.
putFromLoad(Object, Object, long, Object, boolean) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheCollectionRegionAccessStrategy
This method is a placeholder for method signatures supplied by interfaces pulled in further down the class hierarchy.
putFromLoad(Object, Object, long, Object, boolean) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
This method is a placeholder for method signatures supplied by interfaces pulled in further down the class hierarchy.
putIfAbsent(Element) - Method in class net.sf.ehcache.Cache
Put an element in the cache if no element is currently mapped to the elements key.
putIfAbsent(Element, boolean) - Method in class net.sf.ehcache.Cache
Put an element in the cache if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Put an element in the cache if no element is currently mapped to the elements key.
putIfAbsent(Element, boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Put an element in the cache if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Put an element in the cache if no element is currently mapped to the elements key.
putIfAbsent(Element, boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Put an element in the cache if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in interface net.sf.ehcache.Ehcache
Put an element in the cache if no element is currently mapped to the elements key.
putIfAbsent(Element, boolean) - Method in interface net.sf.ehcache.Ehcache
Put an element in the cache if no element is currently mapped to the elements key.
putIfAbsent(Object, Element) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
putIfAbsent(Object, Element, long) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
putIfAbsent(Element) - Method in class net.sf.ehcache.store.disk.DiskStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.store.LruMemoryStore
Unsupported in LruMemoryStore
putIfAbsent(Element) - Method in class net.sf.ehcache.store.MemoryStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.store.NullStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in interface net.sf.ehcache.store.Store
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(Element) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Put an element in the store if no element is currently mapped to the elements key.
putIfAbsent(K, V) - Method in class net.sf.ehcache.util.WeakIdentityConcurrentMap
Puts into the underlying
putPinned(Object, Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Map the given value to the given key, replacing any existing mapping for this key, pinning the key in the cache
putQuiet(Element) - Method in class net.sf.ehcache.Cache
Put an element in the cache, without updating statistics, or updating listeners.
putQuiet(Element) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Put an element in the cache, without updating statistics, or updating listeners.
putQuiet(Element) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Put an element in the cache, without updating statistics, or updating listeners.
putQuiet(Element) - Method in interface net.sf.ehcache.Ehcache
Put an element in the cache, without updating statistics, or updating listeners.
putRawIfAbsent(Object, DiskStorageFactory.DiskMarker) - Method in class net.sf.ehcache.store.disk.DiskStore
Put the given encoded element directly into the store
putWithWriter(Element) - Method in class net.sf.ehcache.Cache
Put an element in the cache writing through a CacheWriter.
putWithWriter(Element) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Put an element in the cache writing through a CacheWriter.
putWithWriter(Element) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Put an element in the cache writing through a CacheWriter.
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element) - Method in interface net.sf.ehcache.Ehcache
Put an element in the cache writing through a CacheWriter.
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.store.disk.DiskStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.store.LruMemoryStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.store.MemoryStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.store.NullStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in interface net.sf.ehcache.store.Store
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Puts an item into the store and the cache writer manager in an atomic operation
putWithWriter(Element, CacheWriterManager) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Puts an item into the store and the cache writer manager in an atomic operation

Q

query - Variable in class net.sf.ehcache.hibernate.management.impl.QueryStats
query
Query - Interface in net.sf.ehcache.search
Creates queries for performing cache searches.
QueryStats - Class in net.sf.ehcache.hibernate.management.impl
 
QueryStats(String) - Constructor for class net.sf.ehcache.hibernate.management.impl.QueryStats
 
QueryStats(String, QueryStatistics) - Constructor for class net.sf.ehcache.hibernate.management.impl.QueryStats
 
QueryStats(CompositeData) - Constructor for class net.sf.ehcache.hibernate.management.impl.QueryStats
 
quickSize() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
Returns the number of key-value mappings in this map without locking anything.

R

range(int, int) - Method in class net.sf.ehcache.search.impl.ResultsImpl
Retrieve a subset of the cache results.
range(int, int) - Method in class net.sf.ehcache.search.NullResults
Retrieve a subset of the cache results.
range(int, int) - Method in interface net.sf.ehcache.search.Results
Retrieve a subset of the cache results.
rateLimitPerSecond(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
RateStatistic - Interface in net.sf.ehcache.util.ratestatistics
Rate monitoring statistic.
read(Object) - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Gets an object from the cache.
read(DiskStorageFactory.DiskMarker) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Read the data at the given marker, and return the associated deserialized Element.
ReadCommittedSoftLockFactoryImpl - Class in net.sf.ehcache.transaction
A SoftLockFactory implementation which creates soft locks with Read-Committed isolation level
ReadCommittedSoftLockFactoryImpl(String, String) - Constructor for class net.sf.ehcache.transaction.ReadCommittedSoftLockFactoryImpl
Create a new ReadCommittedSoftLockFactoryImpl instance for a cache
ReadCommittedSoftLockImpl - Class in net.sf.ehcache.transaction
A SoftLock implementation with Read-Committed isolation level
readLock(Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Attempts to read lock the mapping for the given key.
ReadOnlyEhcacheCollectionRegionAccessStrategy - Class in net.sf.ehcache.hibernate.strategy
Ehcache specific read-only collection region access strategy
ReadOnlyEhcacheCollectionRegionAccessStrategy(EhcacheCollectionRegion, Settings) - Constructor for class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheCollectionRegionAccessStrategy
Create a read-only access strategy accessing the given collection region.
ReadOnlyEhcacheEntityRegionAccessStrategy - Class in net.sf.ehcache.hibernate.strategy
Ehcache specific read-only entity region access strategy
ReadOnlyEhcacheEntityRegionAccessStrategy(EhcacheEntityRegion, Settings) - Constructor for class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
Create a read-only access strategy accessing the given entity region.
readUnlock(Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Attempts to read unlock the mapping for the given key.
ReadWriteCopyStrategy<T> - Interface in net.sf.ehcache.store.compound
 
ReadWriteEhcacheCollectionRegionAccessStrategy - Class in net.sf.ehcache.hibernate.strategy
Ehcache specific read/write collection region access strategy
ReadWriteEhcacheCollectionRegionAccessStrategy(EhcacheCollectionRegion, Settings) - Constructor for class net.sf.ehcache.hibernate.strategy.ReadWriteEhcacheCollectionRegionAccessStrategy
Create a read/write access strategy accessing the given collection region.
ReadWriteEhcacheEntityRegionAccessStrategy - Class in net.sf.ehcache.hibernate.strategy
Ehcache specific read/write entity region access strategy
ReadWriteEhcacheEntityRegionAccessStrategy(EhcacheEntityRegion, Settings) - Constructor for class net.sf.ehcache.hibernate.strategy.ReadWriteEhcacheEntityRegionAccessStrategy
Create a read/write access strategy accessing the given entity region.
ReadWriteLockSync - Class in net.sf.ehcache.concurrent
A simple ReadWriteLock synchronizer.
ReadWriteLockSync() - Constructor for class net.sf.ehcache.concurrent.ReadWriteLockSync
default constructor.
ReadWriteLockSync(ReentrantReadWriteLock) - Constructor for class net.sf.ehcache.concurrent.ReadWriteLockSync
Constructor.
ReadWriteSerializationCopyStrategy - Class in net.sf.ehcache.store.compound
A copy strategy that can use partial (if both copy on read and copy on write are set) or full Serialization to copy the object graph
ReadWriteSerializationCopyStrategy() - Constructor for class net.sf.ehcache.store.compound.ReadWriteSerializationCopyStrategy
 
recalculateSize(Object) - Method in class net.sf.ehcache.Cache
Recalculate the size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.constructs.classloader.InternalClassLoaderAwareCache
Recalculate the size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Recalculate the size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Recalculate size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Recalculate size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Recalculate size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Recalculate size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Recalculate size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.store.AbstractStore
Recalculate size of the element mapped to the key
recalculateSize(Object) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
recalculateSize(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
 
recalculateSize(Object) - Method in class net.sf.ehcache.store.MemoryStore
 
recalculateSize(Object) - Method in class net.sf.ehcache.store.NullStore
Recalculate size of the element mapped to the key
recalculateSize(Object) - Method in interface net.sf.ehcache.store.Store
Recalculate size of the element mapped to the key
recalculateSize(Object) - Method in interface net.sf.ehcache.terracotta.InternalEhcache
Recalculate the size of the element mapped to the key
recover(int) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
recreateCount - Variable in class net.sf.ehcache.hibernate.management.impl.CollectionStats
recreateCount
ReflectionAttributeExtractor - Class in net.sf.ehcache.search.attribute
Built-in search attribute extractor driven by method/value dotted expression chains.

The expression chain must start with one of either "key", "value", or "element".
ReflectionAttributeExtractor(String) - Constructor for class net.sf.ehcache.search.attribute.ReflectionAttributeExtractor
Create a new ReflectionAttributeExtractor
ReflectionSizeOf - Class in net.sf.ehcache.pool.sizeof
SizeOf that uses reflection to measure on heap size of object graphs
ReflectionSizeOf() - Constructor for class net.sf.ehcache.pool.sizeof.ReflectionSizeOf
Builds a new SizeOf that will not filter fields and will cache reflected fields
ReflectionSizeOf(SizeOfFilter) - Constructor for class net.sf.ehcache.pool.sizeof.ReflectionSizeOf
Builds a new SizeOf that will filter fields and will cache reflected fields
ReflectionSizeOf(SizeOfFilter, boolean) - Constructor for class net.sf.ehcache.pool.sizeof.ReflectionSizeOf
Builds a new SizeOf that will filter fields
refresh() - Method in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Refresh the elements of this cache.
refresh(boolean) - Method in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Refresh the elements of this cache.
refresh(Object) - Method in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Refresh a single element.
refresh(Object, boolean) - Method in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Refresh a single element.
refresh() - Method in class net.sf.ehcache.constructs.blocking.UpdatingSelfPopulatingCache
This method should not be used.
refreshElement(Element, Ehcache) - Method in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Refresh a single element.
refreshElement(Element, Ehcache, boolean) - Method in class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Refresh a single element.
region - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
region name
Region - Class in net.sf.ehcache.store.disk.ods
Class that represents the regions held within this set.
Region(long) - Constructor for class net.sf.ehcache.store.disk.ods.Region
Creates a region containing just the single given value
Region(long, long) - Constructor for class net.sf.ehcache.store.disk.ods.Region
Creates a region containing the given range of value (inclusive).
Region(Region) - Constructor for class net.sf.ehcache.store.disk.ods.Region
Create a shallow copy of a region.
register(MBeanServer) - Method in interface net.sf.ehcache.management.ManagedCacheManagerPeerProvider
Register the peer provider with the MBeanServer
register(EhcacheXAResource) - Method in class net.sf.ehcache.transaction.manager.DefaultTransactionManagerLookup
execute txnManager specific code to register the XAResource for recovery.
register(EhcacheXAResource) - Method in interface net.sf.ehcache.transaction.manager.TransactionManagerLookup
execute txnManager specific code to register the XAResource for recovery.
registerCacheExtension(CacheExtension) - Method in class net.sf.ehcache.Cache
Register a CacheExtension with the cache.
registerCacheExtension(CacheExtension) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Register a CacheExtension with the cache.
registerCacheExtension(CacheExtension) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Register a CacheExtension with the cache.
registerCacheExtension(CacheExtension) - Method in interface net.sf.ehcache.Ehcache
Register a CacheExtension with the cache.
registerCacheLoader(CacheLoader) - Method in class net.sf.ehcache.Cache
Register a CacheLoader with the cache.
registerCacheLoader(CacheLoader) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Register a CacheLoader with the cache.
registerCacheLoader(CacheLoader) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Register a CacheLoader with the cache.
registerCacheLoader(CacheLoader) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Register a CacheLoader with the cache.
registerCacheLoader(CacheLoader) - Method in interface net.sf.ehcache.Ehcache
Register a CacheLoader with the cache.
registerCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.Cache
Registers a CacheUsageListener which will be notified of the cache usage.
registerCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Registers a CacheUsageListener which will be notified of the cache usage.
registerCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Registers a CacheUsageListener which will be notified of the cache usage.
registerCacheUsageListener(CacheUsageListener) - Method in interface net.sf.ehcache.Ehcache
Registers a CacheUsageListener which will be notified of the cache usage.
registerCacheUsageListener(CacheUsageListener) - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Registers a CacheUsageListener which will be notified of the cache usage.
registerCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Registers a CacheUsageListener which will be notified of the cache usage.
registerCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Registers a CacheUsageListener which will be notified of the cache usage.
registerCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Registers a CacheUsageListener which will be notified of the cache usage.
registerCacheWriter(CacheWriter) - Method in class net.sf.ehcache.Cache
Register the CacheWriter for this cache.
registerCacheWriter(CacheWriter) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Register the CacheWriter for this cache.
registerCacheWriter(CacheWriter) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Register the CacheWriter for this cache.
registerCacheWriter(CacheWriter) - Method in interface net.sf.ehcache.Ehcache
Register the CacheWriter for this cache.
registered(CacheConfiguration) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates that this listener was registered with the given configuration
registered(CacheConfiguration) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates that this listener was registered with the given configuration
registered(CacheConfiguration) - Method in class net.sf.ehcache.store.MemoryStore
Indicates that this listener was registered with the given configuration
RegisteredEventListeners - Class in net.sf.ehcache.event
Registered listeners for registering and unregistering CacheEventListeners and multicasting notifications to registrants.
RegisteredEventListeners(Ehcache) - Constructor for class net.sf.ehcache.event.RegisteredEventListeners
Constructs a new notification service
RegisteredEventListeners.ElementCreationCallback - Interface in net.sf.ehcache.event
Callback interface for creating elements to pass to registered listeners.
registerListener(CacheManagerEventListener) - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Adds a listener to the notification service.
registerListener(CacheEventListener) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Adds a listener to the notification service.
registerListener(CacheEventListener, NotificationScope) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Adds a listener to the notification service.
registerMBean(CacheManager, Properties) - Method in class net.sf.ehcache.hibernate.management.impl.ProviderMBeanRegistrationHelper
Registers mbean for the input cache manager and the session factory name
registerMBeanForCacheManager(CacheManager, Properties) - Method in interface net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistration
Registers MBean for the input manager and session factory properties.
registerMBeanForCacheManager(CacheManager, Properties) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernateMBeanRegistrationImpl
Registers MBean for the input manager and session factory properties.
registerMBeans(CacheManager, MBeanServer, boolean, boolean, boolean, boolean, boolean) - Static method in class net.sf.ehcache.management.ManagementService
A convenience static method which creates a ManagementService and initialises it with the supplied parameters.
registerMBeans(CacheManager, MBeanServer, boolean, boolean, boolean, boolean) - Static method in class net.sf.ehcache.management.ManagementService
A convenience static method which creates a ManagementService and initialises it with the supplied parameters.
registerPeer(String) - Method in interface net.sf.ehcache.distribution.CacheManagerPeerProvider
Register a new peer.
registerPeer(String) - Method in class net.sf.ehcache.distribution.ManualRMICacheManagerPeerProvider
Register a new peer.
registerPeer(String) - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
Register a new peer, but only if the peer is new, otherwise the last seen timestamp is updated.
registerPeer(String) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
Register a new peer
registerPoolAccessor(PoolAccessor<? extends T>) - Method in class net.sf.ehcache.pool.impl.AbstractPool
Register an accessor implementation with this pool.
registerPoolAccessor(PoolAccessor<? extends PoolableStore>) - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Register an accessor implementation with this pool.
registerPoolAccessor(PoolAccessor<? extends T>) - Method in interface net.sf.ehcache.pool.Pool
Register an accessor implementation with this pool.
registerSoftLock(String, LocalTransactionStore, SoftLock) - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Register a soft lock in the context
reinitialize(ClusteredInstanceFactory) - Method in interface net.sf.ehcache.management.provider.MBeanRegistrationProvider
Reinitialize the mbeans.
reinitialize(ClusteredInstanceFactory) - Method in class net.sf.ehcache.management.provider.MBeanRegistrationProviderImpl
Reinitialize the mbeans.
reinitialize(ClusteredInstanceFactory) - Method in class net.sf.ehcache.management.provider.NullMBeanRegistrationProvider
A null implementation of MBeanRegistrationProvider.reinitialize(ClusteredInstanceFactory)
reinitialize(ClusteredInstanceFactory) - Method in class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Reinitialize the mbeans.
rejoin(boolean) - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Builder method to set rejoin
RejoinAwareBlockingOperation<V> - Class in net.sf.ehcache.constructs.nonstop.store
A Callable implementation that accepts another callable delegate for executing it in nonstop+rejoin context.
RejoinAwareBlockingOperation(ExecutorServiceStore, Callable<V>) - Constructor for class net.sf.ehcache.constructs.nonstop.store.RejoinAwareBlockingOperation
Public constructor
RejoinAwareNonstopStore - Interface in net.sf.ehcache.constructs.nonstop.store
Rejoin aware NonstopStore
release(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. Removes the invalidated item.
release(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. Logs an error since items in a read-only cache should not be mutated.
release(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. Soft-unlocks the associated mapping.
release() - Method in class net.sf.ehcache.transaction.xa.processor.XAThreadPool.MultiRunner
Release the wrapped thread back the the containing thread pool
releaseReadLockOnKey(Object) - Method in class net.sf.ehcache.Cache
Release a held read lock for the passed in key
releaseReadLockOnKey(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Release a held read lock for the passed in key
releaseReadLockOnKey(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Release a held read lock for the passed in key
releaseReadLockOnKey(Object) - Method in interface net.sf.ehcache.Ehcache
Release a held read lock for the passed in key
releaseWriteLockOnKey(Object) - Method in class net.sf.ehcache.Cache
Release a held write lock for the passed in key
releaseWriteLockOnKey(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Release a held write lock for the passed in key
releaseWriteLockOnKey(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Release a held write lock for the passed in key
releaseWriteLockOnKey(Object) - Method in interface net.sf.ehcache.Ehcache
Release a held write lock for the passed in key
RemoteCacheException - Exception in net.sf.ehcache.distribution
A Cache Exception in the distribution mechanism.
RemoteCacheException() - Constructor for exception net.sf.ehcache.distribution.RemoteCacheException
Constructor for the RemoteCacheException object.
RemoteCacheException(String) - Constructor for exception net.sf.ehcache.distribution.RemoteCacheException
Constructor for the RemoteCacheException object.
RemoteCacheException(String, Throwable) - Constructor for exception net.sf.ehcache.distribution.RemoteCacheException
Constructor for the RemoteCacheException object.
removalAll() - Method in class net.sf.ehcache.CacheManager
Removes all caches using CacheManager.removeCache(String) for each cache.
remove(Serializable) - Method in class net.sf.ehcache.Cache
Removes an Element from the Cache.
remove(Object) - Method in class net.sf.ehcache.Cache
Removes an Element from the Cache.
remove(Serializable, boolean) - Method in class net.sf.ehcache.Cache
Removes an Element from the Cache.
remove(Object, boolean) - Method in class net.sf.ehcache.Cache
Removes an Element from the Cache.
remove(Serializable, boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes an Element from the Cache.
remove(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes an Element from the Cache.
remove(Serializable) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes an Element from the Cache.
remove(Object, boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes an Element from the Cache.
remove(Object, boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes an Element from the Cache.
remove(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes an Element from the Cache.
remove(Serializable, boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes an Element from the Cache.
remove(Serializable) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes an Element from the Cache.
remove(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Removes an item from the cache.
remove(Serializable) - Method in interface net.sf.ehcache.distribution.CachePeer
Removes an Element from the Cache.
REMOVE - Static variable in class net.sf.ehcache.distribution.LegacyEventMessage
A remove or invalidate event.
remove(Serializable) - Method in class net.sf.ehcache.distribution.RMICachePeer
Removes an Element from the underlying cache without notifying listeners or updating statistics.
remove(Serializable) - Method in class net.sf.ehcache.distribution.TransactionalRMICachePeer
 
remove(Serializable) - Method in interface net.sf.ehcache.Ehcache
Removes an Element from the Cache.
remove(Object) - Method in interface net.sf.ehcache.Ehcache
Removes an Element from the Cache.
remove(Serializable, boolean) - Method in interface net.sf.ehcache.Ehcache
Removes an Element from the Cache.
remove(Object, boolean) - Method in interface net.sf.ehcache.Ehcache
Removes an Element from the Cache.
remove(Object) - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Removes the element which matches the key.
remove(Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
remove(Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
remove(Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Remove the mapping for this key (if any exists).
remove(Object) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheCollectionRegionAccessStrategy
A no-op since this is an asynchronous cache access strategy.
remove(Object) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
A no-op since this is an asynchronous cache access strategy.
remove(Object) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheCollectionRegionAccessStrategy
A no-op since this is an asynchronous cache access strategy.
remove(Object) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
A no-op since this is an asynchronous cache access strategy.
remove(Object) - Method in class net.sf.ehcache.store.CacheKeySet
You can't remove from this set, will throw!
remove(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
 
remove(Region) - Method in class net.sf.ehcache.store.disk.ods.Region
Remove the supplied region from this region.
remove(Object) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.store.LruMemoryStore
Removes an Element from the store.
remove(Object) - Method in class net.sf.ehcache.store.MemoryStore
Removes an Element from the store.
remove(Object) - Method in class net.sf.ehcache.store.NullStore
Removes an item from the cache.
remove(Object) - Method in interface net.sf.ehcache.store.Store
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Removes an item from the cache.
remove(Object) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Removes an item from the cache.
remove() - Method in class net.sf.ehcache.util.AggregateIterator
remove() - Method in class net.sf.ehcache.util.lang.VicariousThreadLocal
 
remove(Object) - Method in class net.sf.ehcache.util.LargeCollection
remove(Object) - Method in class net.sf.ehcache.util.SetAsList
remove(int) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
remove(CacheEntry) - Method in interface net.sf.ehcache.writer.CacheWriterManager
Schedule a remove operation for this key in the CacheWriterManager, which will call the CacheWriter when appropriate.
remove(CacheEntry) - Method in class net.sf.ehcache.writer.writebehind.WriteBehindManager
Schedule a remove operation for this key in the CacheWriterManager, which will call the CacheWriter when appropriate.
remove(CacheEntry) - Method in class net.sf.ehcache.writer.writethrough.WriteThroughManager
Schedule a remove operation for this key in the CacheWriterManager, which will call the CacheWriter when appropriate.
REMOVE_ALL - Static variable in class net.sf.ehcache.distribution.LegacyEventMessage
A removeAll, which removes all elements from a cache
removeAll(Collection<?>) - Method in class net.sf.ehcache.Cache
Removes given set of Element from the Cache.
removeAll(Collection<?>, boolean) - Method in class net.sf.ehcache.Cache
Removes all cached items.
removeAll() - Method in class net.sf.ehcache.Cache
Removes all cached items.
removeAll(boolean) - Method in class net.sf.ehcache.Cache
Removes all cached items.
removeAll(boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes all cached items.
removeAll() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes all cached items.
removeAll(Collection, boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes all cached items.
removeAll(Collection) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes given set of Element from the Cache.
removeAll(Collection<?>) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes given set of Element from the Cache.
removeAll(Collection<?>, boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes all cached items.
removeAll() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes all cached items.
removeAll(boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes all cached items.
removeAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Removes a collection of elements from the cache.
removeAll() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Remove all of the elements from the store.
removeAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Removes a collection of elements from the cache.
removeAll() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Remove all of the elements from the store.
removeAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Removes a collection of elements from the cache.
removeAll() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Remove all of the elements from the store.
removeAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Removes a collection of elements from the cache.
removeAll() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Remove all of the elements from the store.
removeAll(Collection<?>) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Removes a collection of elements from the cache.
removeAll() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Remove all of the elements from the store.
removeAll() - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Remove all of the elements from the store.
removeAll() - Method in interface net.sf.ehcache.distribution.CachePeer
Removes all cached items.
removeAll() - Method in class net.sf.ehcache.distribution.RMICachePeer
Removes all cached items.
removeAll() - Method in class net.sf.ehcache.distribution.TransactionalRMICachePeer
 
removeAll(Collection<?>) - Method in interface net.sf.ehcache.Ehcache
Removes given set of Element from the Cache.
removeAll(Collection<?>, boolean) - Method in interface net.sf.ehcache.Ehcache
Removes all cached items.
removeAll() - Method in interface net.sf.ehcache.Ehcache
Removes all cached items.
removeAll(boolean) - Method in interface net.sf.ehcache.Ehcache
Removes all cached items.
removeAll() - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
removeAll() - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
removeAll() - Method in class net.sf.ehcache.management.Cache
Removes all cached items.
removeAll() - Method in interface net.sf.ehcache.management.CacheMBean
Removes all cached items.
removeAll() - Method in class net.sf.ehcache.management.sampled.SampledCache
Removes all cached items.
removeAll() - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Removes all cached items.
removeAll(Collection<?>) - Method in class net.sf.ehcache.store.AbstractStore
Removes a collection of elements from the cache.
removeAll(Collection<?>) - Method in class net.sf.ehcache.store.CacheKeySet
You can't remove from this set, will throw!
removeAll() - Method in class net.sf.ehcache.store.disk.DiskStore
Remove all of the elements from the store.
removeAll() - Method in class net.sf.ehcache.store.FrontEndCacheTier
Remove all of the elements from the store.
removeAll() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Remove all of the elements from the store.
removeAll() - Method in class net.sf.ehcache.store.LruMemoryStore
Remove all of the elements from the store.
removeAll() - Method in class net.sf.ehcache.store.MemoryStore
Remove all of the elements from the store.
removeAll() - Method in class net.sf.ehcache.store.NullStore
Remove all of the elements from the store.
removeAll(Collection<?>) - Method in interface net.sf.ehcache.store.Store
Removes a collection of elements from the cache.
removeAll() - Method in interface net.sf.ehcache.store.Store
Remove all of the elements from the store.
removeAll(Collection<?>) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Removes a collection of elements from the cache.
removeAll() - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Remove all of the elements from the store.
removeAll() - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Remove all of the elements from the store.
removeAll() - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Remove all of the elements from the store.
removeAll(Collection<?>) - Method in class net.sf.ehcache.util.LargeCollection
removeAll(Collection<?>) - Method in class net.sf.ehcache.util.SetAsList
removeAndReturn(Object) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
Remove the node matching this object and return it.
removeAndReturnElement(Object) - Method in class net.sf.ehcache.Cache
Removes an Element from the Cache and returns it.
removeAndReturnElement(Object) - Method in class net.sf.ehcache.constructs.classloader.InternalClassLoaderAwareCache
Removes and returns the element associated with the key
removeAndReturnElement(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes and returns the element associated with the key
removeAndReturnElement(Object) - Method in interface net.sf.ehcache.terracotta.InternalEhcache
Removes and returns the element associated with the key
removeCache(String) - Method in class net.sf.ehcache.CacheManager
Remove a cache from the CacheManager.
removeCache(CacheConfiguration) - Method in class net.sf.ehcache.config.Configuration.RuntimeCfg
Removes a cache from the known list
removeCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.Cache
Remove an already registered CacheUsageListener, if any.
removeCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Remove an already registered CacheUsageListener, if any.
removeCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Remove an already registered CacheUsageListener, if any.
removeCacheUsageListener(CacheUsageListener) - Method in interface net.sf.ehcache.Ehcache
Remove an already registered CacheUsageListener, if any.
removeCacheUsageListener(CacheUsageListener) - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Remove an already registered CacheUsageListener, if any.
removeCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Remove an already registered CacheUsageListener, if any.
removeCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Remove an already registered CacheUsageListener, if any.
removeCacheUsageListener(CacheUsageListener) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Remove an already registered CacheUsageListener, if any.
removeConfigurationListener(CacheConfigurationListener) - Method in class net.sf.ehcache.config.CacheConfiguration
Remove the supplied cache configuration listener.
removeCount - Variable in class net.sf.ehcache.hibernate.management.impl.CollectionStats
removeCount
removeEldestEntry(Map.Entry) - Method in class net.sf.ehcache.store.LruMemoryStore.SpoolingLinkedHashMap
Returns true if this map should remove its eldest entry.
removeElement(Element) - Method in class net.sf.ehcache.Cache
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element) - Method in interface net.sf.ehcache.Ehcache
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.store.disk.DiskStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.store.LruMemoryStore
Unsupported in LruMemoryStore
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.store.MemoryStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.store.NullStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in interface net.sf.ehcache.store.Store
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeElement(Element, ElementValueComparator) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Remove the Element mapped to the key for the supplied element if the value of the supplied Element is equal to the value of the cached Element.
removeIfTierNotPinned(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
Removes the element if the tier.
removeIfTierNotPinned(Object) - Method in class net.sf.ehcache.store.MemoryStore
Removes the element if the tier.
removeIfTierNotPinned(Object) - Method in class net.sf.ehcache.store.NullStore
Removes the element if the tier.
removeIfTierNotPinned(Object) - Method in interface net.sf.ehcache.store.TierableStore
Removes the element if the tier.
removeNoReturn(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
Removes an item from the cache.
removeNoReturn(Object) - Method in class net.sf.ehcache.store.MemoryStore
Removes an item from the cache.
removeNoReturn(Object) - Method in class net.sf.ehcache.store.NullStore
Removes an item from the cache.
removeNoReturn(Object) - Method in interface net.sf.ehcache.store.TierableStore
Removes an item from the cache.
removeNotificationListener(NotificationListener) - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
 
removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
 
removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
 
removeNotificationListener(NotificationListener) - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
 
removePoolAccessor(PoolAccessor<?>) - Method in class net.sf.ehcache.pool.impl.AbstractPool
Remove the supplied accessor from this pool.
removePoolAccessor(PoolAccessor<?>) - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Remove the supplied accessor from this pool.
removePoolAccessor(PoolAccessor<?>) - Method in interface net.sf.ehcache.pool.Pool
Remove the supplied accessor from this pool.
removePropertyChangeListener(PropertyChangeListener) - Method in class net.sf.ehcache.Cache
 
removePropertyChangeListener(PropertyChangeListener) - Method in class net.sf.ehcache.config.Configuration
Removes a PropertyChangeListener for this configuration
removePropertyChangeListener(PropertyChangeListener) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Remove a PropertyChangeListener.
removePropertyChangeListener(PropertyChangeListener) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Remove a PropertyChangeListener.
removePropertyChangeListener(PropertyChangeListener) - Method in interface net.sf.ehcache.Ehcache
Remove a PropertyChangeListener.
removeQuiet(Serializable) - Method in class net.sf.ehcache.Cache
Removes an Element from the Cache, without notifying listeners.
removeQuiet(Object) - Method in class net.sf.ehcache.Cache
Removes an Element from the Cache, without notifying listeners.
removeQuiet(Serializable) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes an Element from the Cache, without notifying listeners.
removeQuiet(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes an Element from the Cache, without notifying listeners.
removeQuiet(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes an Element from the Cache, without notifying listeners.
removeQuiet(Serializable) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes an Element from the Cache, without notifying listeners.
removeQuiet(Serializable) - Method in interface net.sf.ehcache.Ehcache
Removes an Element from the Cache, without notifying listeners.
removeQuiet(Object) - Method in interface net.sf.ehcache.Ehcache
Removes an Element from the Cache, without notifying listeners.
removeStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Remove listener from store.
removeStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Remove listener from store.
removeStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Remove listener from store.
removeStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Remove listener from store.
removeStoreListener(StoreListener) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Remove listener from store.
removeStoreListener(StoreListener) - Method in class net.sf.ehcache.store.AbstractStore
Remove listener from store.
removeStoreListener(StoreListener) - Method in interface net.sf.ehcache.store.Store
Remove listener from store.
removeTopologyListener(ClusterTopologyListener) - Method in interface net.sf.ehcache.cluster.CacheCluster
Remove a listener for cluster events
removeTopologyListener(ClusterTopologyListener) - Method in class net.sf.ehcache.cluster.NoopCacheCluster
Remove a listener for cluster events
removeTopologyListener(ClusterTopologyListener) - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Remove a listener for cluster events
removeWithWriter(Object) - Method in class net.sf.ehcache.Cache
Removes an Element from the Cache and any stores it might be in.
removeWithWriter(Object) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Removes an Element from the Cache and any stores it might be in.
removeWithWriter(Object) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Removes an Element from the Cache and any stores it might be in.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object) - Method in interface net.sf.ehcache.Ehcache
Removes an Element from the Cache and any stores it might be in.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.store.disk.DiskStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.store.LruMemoryStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.store.MemoryStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.store.NullStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in interface net.sf.ehcache.store.Store
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Removes an item from the store and the cache writer manager in an atomic operation.
removeWithWriter(Object, CacheWriterManager) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Removes an item from the store and the cache writer manager in an atomic operation.
replace(Element, Element) - Method in class net.sf.ehcache.Cache
Replace the cached element only if the current Element is equal to the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.Cache
Replace the cached element only if an Element is currently cached for this key
replace(Element) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Replace the cached element only if the current Element is equal to the supplied old Element.
replace(Element, Element) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Replace the cached element only if the current Element is equal to the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Replace the cached element only if an Element is currently cached for this key
replace(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Replace the cached element only if an Element is currently cached for this key
replace(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element) - Method in interface net.sf.ehcache.Ehcache
Replace the cached element only if the current Element is equal to the supplied old Element.
replace(Element) - Method in interface net.sf.ehcache.Ehcache
Replace the cached element only if an Element is currently cached for this key
replace(long, Object, Object, Object, boolean) - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Delete a fixed number of bytes from the pool with the given objects.
replace(long, Object, Object, Object, boolean) - Method in interface net.sf.ehcache.pool.PoolAccessor
Delete a fixed number of bytes from the pool with the given objects.
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.store.disk.DiskStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.store.disk.DiskStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.store.LruMemoryStore
Unsupported in LruMemoryStore
replace(Element) - Method in class net.sf.ehcache.store.LruMemoryStore
Unsupported in LruMemoryStore
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.store.MemoryStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.store.MemoryStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.store.NullStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.store.NullStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in interface net.sf.ehcache.store.Store
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in interface net.sf.ehcache.store.Store
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.transaction.local.JtaLocalTransactionStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Replace the cached element only if an Element is currently cached for this key
replace(Element, Element, ElementValueComparator) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Replace the cached element only if the value of the current Element is equal to the value of the supplied old Element.
replace(Element) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Replace the cached element only if an Element is currently cached for this key
replaceCacheWithDecoratedCache(Ehcache, Ehcache) - Method in class net.sf.ehcache.CacheManager
Replaces in the map of Caches managed by this CacheManager an Ehcache with a decorated version of the same Ehcache.
replicatePutNotification(Ehcache, Element) - Static method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Does the actual RMI remote call.
replicatePuts - Variable in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Whether to replicate puts.
replicatePutsViaCopy - Variable in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Whether a put should replicated by copy or by invalidation, (a remove).
replicateRemovalNotification(Ehcache, Serializable) - Static method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Does the actual RMI remote call.
replicateRemovals - Variable in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Whether to replicate removes
replicateRemoveAllNotification(Ehcache) - Method in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Does the actual RMI remote call.
replicateUpdates - Variable in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Whether to replicate updates.
replicateUpdatesViaCopy - Variable in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Whether an update (a put) should be by copy or by invalidation, (a remove).
requestedAttributes() - Method in interface net.sf.ehcache.store.StoreQuery
Get the set of attributes requested by this query
requestsKeys() - Method in interface net.sf.ehcache.store.StoreQuery
Are keys requested?
requestsValues() - Method in interface net.sf.ehcache.store.StoreQuery
Are values requested?
resetAccessStatistics() - Method in class net.sf.ehcache.Element
Resets the hit count to 0 and the last access time to now.
resetLastAccessTime(Element) - Method in class net.sf.ehcache.DefaultElementEvictionData
Resets the last access time.
resetLastAccessTime(Element) - Method in interface net.sf.ehcache.ElementEvictionData
Resets the last access time.
resetOnSample - Variable in class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
Should the counter reset on each sample?
resolveBehavior(Ehcache) - Static method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Helper method which resolves the MaxDepthExceededBehavior of a cache, using the cache manager's one if none was configured on the cache itself.
resolveClass(ObjectStreamClass) - Method in class net.sf.ehcache.util.PreferTCCLObjectInputStream
 
resolveMaxDepth(Ehcache) - Static method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Helper method which resolves the max depth of a cache, using the cache manager's one if none was configured on the cache itself.
resolveTimeoutBehaviorStore() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Get the timeout behavior resolver NonstopStore
resolveTimeoutBehaviorStore() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Resolve the NonstopStore to be used
resolveTimeoutBehaviorStore() - Method in interface net.sf.ehcache.constructs.nonstop.store.NonstopTimeoutBehaviorStoreResolver
Resolve the NonstopStore to be used
ResourceSizeOfFilter - Class in net.sf.ehcache.pool.sizeof.filter
Filters based on a configuration file
ResourceSizeOfFilter(URL) - Constructor for class net.sf.ehcache.pool.sizeof.filter.ResourceSizeOfFilter
Builds a filter based on the provided configuration URL
restoreTransactionID(TransactionIDSerializedForm) - Method in class net.sf.ehcache.transaction.DelegatingTransactionIDFactory
Restore a transaction ID from its serialized form
restoreTransactionID(TransactionIDSerializedForm) - Method in interface net.sf.ehcache.transaction.TransactionIDFactory
Restore a transaction ID from its serialized form
restoreTransactionID(TransactionIDSerializedForm) - Method in class net.sf.ehcache.transaction.TransactionIDFactoryImpl
Restore a transaction ID from its serialized form
restoreXidTransactionID(XidTransactionIDSerializedForm) - Method in class net.sf.ehcache.transaction.DelegatingTransactionIDFactory
Restore a XID transaction ID from its serialized form
restoreXidTransactionID(XidTransactionIDSerializedForm) - Method in interface net.sf.ehcache.transaction.TransactionIDFactory
Restore a XID transaction ID from its serialized form
restoreXidTransactionID(XidTransactionIDSerializedForm) - Method in class net.sf.ehcache.transaction.TransactionIDFactoryImpl
Restore a XID transaction ID from its serialized form
Result - Interface in net.sf.ehcache.search
Represents a single cache entry that has been selected by a cache query.
ResultImpl - Class in net.sf.ehcache.search.impl
Result implementation
ResultImpl(Object, Object, StoreQuery, Map<String, Object>, Object[]) - Constructor for class net.sf.ehcache.search.impl.ResultImpl
Constructor
Results - Interface in net.sf.ehcache.search
Results object for an execution of a Query.
ResultsImpl - Class in net.sf.ehcache.search.impl
Results implementation
ResultsImpl(List<Result>, boolean, boolean, boolean, boolean) - Constructor for class net.sf.ehcache.search.impl.ResultsImpl
Constructor
retainAll(Collection<?>) - Method in class net.sf.ehcache.store.CacheKeySet
You can't remove from this set, will throw!
retainAll(Collection<?>) - Method in class net.sf.ehcache.util.SetAsList
retrieve(DiskStorageFactory.DiskSubstitute) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Decodes the supplied DiskStorageFactory.DiskSubstitute.
retrieve(DiskStorageFactory.DiskSubstitute, Segment) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Decodes the supplied DiskStorageFactory.DiskSubstitute, updating statistics.
retryAttemptDelaySeconds(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
retryAttempts(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
RMIAsynchronousCacheReplicator - Class in net.sf.ehcache.distribution
Listens to CacheManager and Cache events and propagates those to CachePeer peers of the Cache asynchronously.
RMIAsynchronousCacheReplicator(boolean, boolean, boolean, boolean, boolean, int, int) - Constructor for class net.sf.ehcache.distribution.RMIAsynchronousCacheReplicator
Constructor for internal and subclass use
RMIBootstrapCacheLoader - Class in net.sf.ehcache.distribution
Loads Elements from a random Cache Peer
RMIBootstrapCacheLoader(boolean, int) - Constructor for class net.sf.ehcache.distribution.RMIBootstrapCacheLoader
Creates a boostrap cache loader that will work with RMI based distribution
RMIBootstrapCacheLoaderFactory - Class in net.sf.ehcache.distribution
A factory to create a configured RMIBootstrapCacheLoader
RMIBootstrapCacheLoaderFactory() - Constructor for class net.sf.ehcache.distribution.RMIBootstrapCacheLoaderFactory
 
RMICacheManagerPeerListener - Class in net.sf.ehcache.distribution
A cache server which exposes available cache operations remotely through RMI.
RMICacheManagerPeerListener(String, Integer, Integer, CacheManager, Integer) - Constructor for class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Constructor with full arguments.
RMICacheManagerPeerListenerFactory - Class in net.sf.ehcache.distribution
Builds a listener based on RMI.
RMICacheManagerPeerListenerFactory() - Constructor for class net.sf.ehcache.distribution.RMICacheManagerPeerListenerFactory
 
RMICacheManagerPeerProvider - Class in net.sf.ehcache.distribution
A provider of Peer RMI addresses.
RMICacheManagerPeerProvider(CacheManager) - Constructor for class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
Constructor
RMICacheManagerPeerProvider() - Constructor for class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
Empty constructor
RMICacheManagerPeerProviderFactory - Class in net.sf.ehcache.distribution
Builds a factory based on RMI
RMICacheManagerPeerProviderFactory() - Constructor for class net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory
 
RMICachePeer - Class in net.sf.ehcache.distribution
An RMI based implementation of CachePeer.
RMICachePeer(Ehcache, String, Integer, Integer, Integer) - Constructor for class net.sf.ehcache.distribution.RMICachePeer
Construct a new remote peer.
RMICacheReplicatorFactory - Class in net.sf.ehcache.distribution
Creates an RMICacheReplicator using properties.
RMICacheReplicatorFactory() - Constructor for class net.sf.ehcache.distribution.RMICacheReplicatorFactory
 
RmiEventMessage - Class in net.sf.ehcache.distribution
 
RmiEventMessage(Ehcache, RmiEventMessage.RmiEventType, Serializable, Element) - Constructor for class net.sf.ehcache.distribution.RmiEventMessage
Full constructor.
RmiEventMessage.RmiEventType - Enum in net.sf.ehcache.distribution
Enumeration of event types.
RMISynchronousCacheReplicator - Class in net.sf.ehcache.distribution
Listens to CacheManager and Cache events and propagates those to CachePeer peers of the Cache.
RMISynchronousCacheReplicator(boolean, boolean, boolean, boolean, boolean) - Constructor for class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
Constructor for internal and subclass use
roleName - Variable in class net.sf.ehcache.hibernate.management.impl.CollectionStats
roleName
rollback() - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Rollback all work done in the context and release all registered soft locks
rollback(Store) - Method in class net.sf.ehcache.transaction.xa.commands.AbstractStoreCommand
Rollback the prepared change
rollback(Store) - Method in interface net.sf.ehcache.transaction.xa.commands.Command
Rollback the prepared change
rollback(Xid) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
rollback() - Method in class net.sf.ehcache.TransactionController
Rollback the transaction bound to the current thread
rollbackInternal(Xid) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
The rollback implementation
run() - Method in class net.sf.ehcache.transaction.xa.processor.XAThreadPool.MultiRunner
run() - Method in class net.sf.ehcache.util.UpdateChecker
Run the update check

S

SAMPLED_CACHE_MANAGER_TYPE - Static variable in class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
Type used for sampled cache manager mbean
SAMPLED_CACHE_TYPE - Static variable in class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
Type used for sampled cache mbean
SampledCache - Class in net.sf.ehcache.management.sampled
An implementation of SampledCacheMBean

SampledCache(Ehcache) - Constructor for class net.sf.ehcache.management.sampled.SampledCache
Constructor accepting the backing Ehcache
SampledCacheManager - Class in net.sf.ehcache.management.sampled
An implementation of SampledCacheManagerMBean

SampledCacheManager(CacheManager) - Constructor for class net.sf.ehcache.management.sampled.SampledCacheManager
Constructor taking the backing CacheManager
SampledCacheManagerMBean - Interface in net.sf.ehcache.management.sampled
An MBean for CacheManager exposing sampled cache usage statistics

SampledCacheMBean - Interface in net.sf.ehcache.management.sampled
An MBean for Cache exposing cache statistics.
SampledCacheStatistics - Interface in net.sf.ehcache.statistics.sampled
Interface for sampled usage statistics of a Cache

SampledCacheStatisticsImpl - Class in net.sf.ehcache.statistics.sampled
An implementation of SampledCacheStatistics This also implements CacheUsageListener and depends on the notification received from these to update the stats

SampledCacheStatisticsImpl(FailSafeTimer) - Constructor for class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsImpl
Constructor that accepts a timer which will be used to schedule the sampled counters
SampledCacheStatisticsWrapper - Class in net.sf.ehcache.statistics.sampled
An implementation of SampledCacheStatistics and also implements CacheUsageListener and depends on the notification received from these to update the stats.
SampledCacheStatisticsWrapper() - Constructor for class net.sf.ehcache.statistics.sampled.SampledCacheStatisticsWrapper
Default constructor.
SampledCounter - Interface in net.sf.ehcache.util.counter.sampled
Interface of a sampled counter -- a counter that keeps sampled values
SampledCounterConfig - Class in net.sf.ehcache.util.counter.sampled
Config for a SampledCounter
SampledCounterConfig(int, int, boolean, long) - Constructor for class net.sf.ehcache.util.counter.sampled.SampledCounterConfig
Make a new timed counter config (duh)
SampledCounterImpl - Class in net.sf.ehcache.util.counter.sampled
An implementation of SampledCounter
SampledCounterImpl(SampledCounterConfig) - Constructor for class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
todo GL how many threads is this creating? Constructor accepting a SampledCounterConfig
SampledEhcacheMBeans - Class in net.sf.ehcache.management.sampled
Utility class used for getting ObjectName's for sampled MBeans

SampledEhcacheMBeans() - Constructor for class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
 
SampledMBeanRegistrationProvider - Class in net.sf.ehcache.management.sampled
An implementation of MBeanRegistrationProvider which registers sampled MBeans for the CacheManager and its Caches.
SampledMBeanRegistrationProvider() - Constructor for class net.sf.ehcache.management.sampled.SampledMBeanRegistrationProvider
Default constructor
SampledRateCounter - Interface in net.sf.ehcache.util.counter.sampled
Interface of a sampled rate counter -- a counter that keeps sampled values of rates
SampledRateCounterConfig - Class in net.sf.ehcache.util.counter.sampled
An implementation of SampledCounterConfig
SampledRateCounterConfig(int, int, boolean) - Constructor for class net.sf.ehcache.util.counter.sampled.SampledRateCounterConfig
Constructor accepting the interval time in seconds, history-size and whether counters should reset on each sample or not.
SampledRateCounterConfig(int, int, boolean, long, long) - Constructor for class net.sf.ehcache.util.counter.sampled.SampledRateCounterConfig
Constructor accepting the interval time in seconds, history-size and whether counters should reset on each sample or not.
SampledRateCounterImpl - Class in net.sf.ehcache.util.counter.sampled
An implementation of SampledRateCounter
SampledRateCounterImpl(SampledRateCounterConfig) - Constructor for class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
Constructor accepting the config
schedule(Callable<U>) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Schedule to given task on the disk writer executor service.
schedule(TimerTask, Date, long) - Method in class net.sf.ehcache.util.FailSafeTimer
If the runtime environment restricts thread creation, the task is run inline for only one time.
schedule(TimerTask, Date) - Method in class net.sf.ehcache.util.FailSafeTimer
If the runtime environment restricts thread creation, the task is run inline for only one time.
schedule(TimerTask, long, long) - Method in class net.sf.ehcache.util.FailSafeTimer
If the runtime environment restricts thread creation, the task is run inline for only one time.
schedule(TimerTask, long) - Method in class net.sf.ehcache.util.FailSafeTimer
If the runtime environment restricts thread creation, the task is run inline for only one time.
scheduleAtFixedRate(TimerTask, Date, long) - Method in class net.sf.ehcache.util.FailSafeTimer
If the runtime environment restricts thread creation, the task is run inline for only one time.
scheduleAtFixedRate(TimerTask, long, long) - Method in class net.sf.ehcache.util.FailSafeTimer
If the runtime environment restricts thread creation, the task is run inline for only one time.
searchable(Searchable) - Method in class net.sf.ehcache.config.CacheConfiguration
 
Searchable - Class in net.sf.ehcache.config
Search configuration for a Cache
Searchable() - Constructor for class net.sf.ehcache.config.Searchable
Constructor
SearchableConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing a Searchable config element
SearchableConfigurationElement(NodeElement, Searchable) - Constructor for class net.sf.ehcache.config.generator.model.elements.SearchableConfigurationElement
Constructor accepting the parent and the Searchable
searchAttribute(SearchAttribute) - Method in class net.sf.ehcache.config.Searchable
Add a search attribute
SearchAttribute - Class in net.sf.ehcache.config
A cache search attribute.
SearchAttribute() - Constructor for class net.sf.ehcache.config.SearchAttribute
 
SearchException - Exception in net.sf.ehcache.search
A generic search exception.
SearchException(String) - Constructor for exception net.sf.ehcache.search.SearchException
Construct a search exception
SearchException(String, Throwable) - Constructor for exception net.sf.ehcache.search.SearchException
Construct a search exception with an underlying cause and message
SearchException(Throwable) - Constructor for exception net.sf.ehcache.search.SearchException
Construct a search exception with an underlying cause
Segment - Class in net.sf.ehcache.store.disk
Segment implementation used in LocalStore.
Segment(int, float, DiskStorageFactory, CacheConfiguration, PoolAccessor, PoolAccessor) - Constructor for class net.sf.ehcache.store.disk.Segment
Create a Segment with the given initial capacity, load-factor, primary element substitute factory, and identity element substitute factory.
SelectableConcurrentHashMap - Class in net.sf.ehcache.store.chm
SelectableConcurrentHashMap subclasses a repackaged version of ConcurrentHashMap ito allow efficient random sampling of the map values.
SelectableConcurrentHashMap(PoolAccessor, boolean, int, float, int, long, RegisteredEventListeners) - Constructor for class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
selectedBasedOnPolicy(Element[], Element) - Method in class net.sf.ehcache.store.AbstractPolicy
Finds the best eviction candidate based on the sampled elements.
selectedBasedOnPolicy(Element[], Element) - Method in interface net.sf.ehcache.store.Policy
Finds the best eviction candidate based on the sampled elements.
selectLock(Object, int) - Static method in class net.sf.ehcache.concurrent.ConcurrencyUtil
Selects a lock for a key.
SelfPopulatingCache - Class in net.sf.ehcache.constructs.blocking
A selfpopulating decorator for Ehcache that creates entries on demand.
SelfPopulatingCache(Ehcache, CacheEntryFactory) - Constructor for class net.sf.ehcache.constructs.blocking.SelfPopulatingCache
Creates a SelfPopulatingCache.
send(List) - Method in interface net.sf.ehcache.distribution.CachePeer
Send the cache peer with an ordered list of EventMessages.
send(List) - Method in class net.sf.ehcache.distribution.RMICachePeer
Send the cache peer with an ordered list of EventMessages

This enables multiple messages to be delivered in one network invocation.

send(List) - Method in class net.sf.ehcache.distribution.TransactionalRMICachePeer
 
sendNotification(String) - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
sendNotification
sendNotification(String, Object) - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
sendNotification
sendNotification(String, Object, String) - Method in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
sendNotification
sequenceNumber - Variable in class net.sf.ehcache.hibernate.management.impl.BaseEmitterBean
sequenceNumber
SerializableXid - Class in net.sf.ehcache.transaction.xa
A serializable XID
SerializableXid(Xid) - Constructor for class net.sf.ehcache.transaction.xa.SerializableXid
Create a SerializableXid, copying the GTRID and BQUAL of an existing XID
SerializationCopyStrategy - Class in net.sf.ehcache.store.compound
A copy strategy that uses full Serialization to copy the object graph
SerializationCopyStrategy() - Constructor for class net.sf.ehcache.store.compound.SerializationCopyStrategy
 
serialize(Serializable, int) - Static method in class net.sf.ehcache.util.MemoryEfficientByteArrayOutputStream
Factory method
serialize(Serializable) - Static method in class net.sf.ehcache.util.MemoryEfficientByteArrayOutputStream
Factory method.
set(T) - Method in class net.sf.ehcache.util.lang.VicariousThreadLocal
 
set(int, E) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
setAggregateResults(List<Object>) - Method in class net.sf.ehcache.search.impl.BaseResult
Set the aggregate results for this row
SetAsList<E> - Class in net.sf.ehcache.util
Wraps a set to provide a list interface.
SetAsList(Set<E>) - Constructor for class net.sf.ehcache.util.SetAsList
 
setAttribute(Attribute) - Method in class net.sf.ehcache.management.Store
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.store.AbstractStore
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.store.MemoryOnlyStore
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in interface net.sf.ehcache.store.Store
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.transaction.local.LocalTransactionStore
Inform this store of the configured attribute extractors.
setAttributeExtractors(Map<String, AttributeExtractor>) - Method in class net.sf.ehcache.transaction.xa.XATransactionStore
Inform this store of the configured attribute extractors.
setAttributes(AttributeList) - Method in class net.sf.ehcache.management.Store
setBootstrapCacheLoader(BootstrapCacheLoader) - Method in class net.sf.ehcache.Cache
Sets the bootstrap cache loader.
setBootstrapCacheLoader(BootstrapCacheLoader) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Sets the bootstrap cache loader.
setBootstrapCacheLoader(BootstrapCacheLoader) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Sets the bootstrap cache loader.
setBootstrapCacheLoader(BootstrapCacheLoader) - Method in interface net.sf.ehcache.Ehcache
Sets the bootstrap cache loader.
setBulkOpsTimeoutMultiplyFactor(int) - Method in class net.sf.ehcache.config.NonstopConfiguration
Sets the value of the multiplication factor for bulk cache operations
setCacheExceptionHandler(CacheExceptionHandler) - Method in class net.sf.ehcache.Cache
Sets an ExceptionHandler on the Cache.
setCacheExceptionHandler(CacheExceptionHandler) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Sets an ExceptionHandler on the Cache.
setCacheExceptionHandler(CacheExceptionHandler) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Sets an ExceptionHandler on the Cache.
setCacheExceptionHandler(CacheExceptionHandler) - Method in interface net.sf.ehcache.Ehcache
Sets an ExceptionHandler on the Cache.
setCacheLoaderTimeoutMillis(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the timeout for CacheLoader execution (0 = no timeout).
setCacheManager(CacheManager) - Method in class net.sf.ehcache.Cache
For use by CacheManager.
setCacheManager(CacheManager) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Sets the CacheManager
setCacheManager(CacheManager) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Sets the CacheManager
setCacheManager(CacheManager) - Method in interface net.sf.ehcache.Ehcache
Sets the CacheManager
setCacheManagerEventListener(CacheManagerEventListener) - Method in class net.sf.ehcache.CacheManager
Same as getCacheManagerEventListenerRegistry().registerListener(cacheManagerEventListener); Left for backward compatiblity
setCacheXA(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Used by BeanHandler to set the cacheXA flag during parsing
setClass(String) - Method in class net.sf.ehcache.config.CopyStrategyConfiguration
Sets the fully qualified class name for the CopyStrategy to use
setClass(String) - Method in class net.sf.ehcache.config.ElementValueComparatorConfiguration
Sets the fully qualified class name for the ElementValueComparator to use
setClass(String) - Method in class net.sf.ehcache.config.FactoryConfiguration
Sets the class name.
setClass(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the extractor class for this attribute.
setClearOnFlush(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets whether the MemoryStore should be cleared when flush() is called on the cache - true by default.
setClustered(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Indicates whether to cluster this cache with Terracotta.
setCoherent(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Deprecated. since 2.4 Use TerracottaConfiguration.setConsistency(Consistency) instead
setCoherentReads(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Sets whether this cache should use coherent reads (usually should be true unless optimizing for read-only).
setCompressionEnabled(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Used by BeanHandler to set the compressionEnaled flag during parsing
setConcurrency(int) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Sets the value of concurrency.
setConsistency(TerracottaConfiguration.Consistency) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Setter for consistency
setConsistency(String) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Setter for consistency
setCopyOnRead(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Whether the Cache should copy elements it returns
setCopyOnRead(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Used by BeanHandler to set the copyOnRead flag during parsing
setCopyOnWrite(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Whether the Cache should copy elements it gets
setCopyStrategyInstance(ReadWriteCopyStrategy<Element>) - Method in class net.sf.ehcache.config.CopyStrategyConfiguration
Sets the CopyStrategy instance to use
setCreateTime() - Method in class net.sf.ehcache.Element
Deprecated. Resetting the creation time is not recommended as of version 1.7
setCreationTime(long) - Method in class net.sf.ehcache.DefaultElementEvictionData
Sets the element creation time.
setCreationTime(long) - Method in interface net.sf.ehcache.ElementEvictionData
Sets the element creation time.
setDefaultCacheConfiguration(CacheConfiguration) - Method in class net.sf.ehcache.config.Configuration
 
setDefaultTransactionTimeout(int) - Method in class net.sf.ehcache.TransactionController
Set the default transaction timeout in seconds, it must be > 0
setDefaultTransactionTimeoutInSeconds(int) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to set the default transaction timeout.
setDefaultValue(String) - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Default value setter
setDefaultValue(String) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Default value setter
setDenominatorValue(long) - Method in interface net.sf.ehcache.util.counter.sampled.SampledRateCounter
Sets the value of the denominator to the passed value
setDenominatorValue(long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
Sets the value of the denominator to the passed value
setDisabled(boolean) - Method in class net.sf.ehcache.Cache
Disables or enables this cache.
setDisabled(boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Disables or enables this cache.
setDisabled(boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Disables or enables this cache.
setDisabled(boolean) - Method in interface net.sf.ehcache.Ehcache
Disables or enables this cache.
setDiskAccessStripes(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the number of disk stripes.
setDiskExpiryThreadIntervalSeconds(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the interval in seconds between runs of the disk expiry thread.
setDiskExpiryThreadIntervalSeconds(long) - Method in class net.sf.ehcache.management.CacheConfiguration
setDiskExpiryThreadIntervalSeconds
setDiskExpiryThreadIntervalSeconds(long) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setDiskExpiryThreadIntervalSeconds
setDiskExpiryThreadIntervalSeconds(long) - Method in class net.sf.ehcache.management.sampled.SampledCache
setDiskExpiryThreadIntervalSeconds
setDiskExpiryThreadIntervalSeconds(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setDiskExpiryThreadIntervalSeconds
setDiskPersistent(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets whether the disk store persists between CacheManager instances.
setDiskPersistent(boolean) - Method in class net.sf.ehcache.management.CacheConfiguration
setDiskPersistent
setDiskPersistent(boolean) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setDiskPersistent
setDiskPersistent(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
setDiskPersistent
setDiskPersistent(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setDiskPersistent
setDiskSpoolBufferSizeMB(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the disk spool size, which is used to buffer writes to the DiskStore.
setDiskSpoolBufferSizeMB(int) - Method in class net.sf.ehcache.management.CacheConfiguration
setDiskSpoolBufferSizeMB
setDiskSpoolBufferSizeMB(int) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setDiskSpoolBufferSizeMB
setDiskStorePath(String) - Method in class net.sf.ehcache.Cache
DiskStore paths can conflict between CacheManager instances.
setDiskStorePath(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the path that will be used for the disk store.
setDiskStorePath(String) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
DiskStore paths can conflict between CacheManager instances.
setDiskStorePath(String) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
DiskStore paths can conflict between CacheManager instances.
setDiskStorePath(String) - Method in interface net.sf.ehcache.Ehcache
DiskStore paths can conflict between CacheManager instances.
setDynamicConfig(boolean) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to set the dynamic configuration flag
setElementEvictionData(ElementEvictionData) - Method in class net.sf.ehcache.Element
Sets this element's eviction data instance.
setEnabled(boolean) - Method in class net.sf.ehcache.config.NonstopConfiguration
Set the value of nonstop is enabled or not
setEnabled(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
Enabled/disable the cache.
setEnabled(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Enables/disables each of the contained caches.
setEnabled(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Enables/disables each cache contained by this CacheManager
setEnabled(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Enabled/disable the cache.
setEternal(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets whether elements are eternal.
setEternal(boolean) - Method in class net.sf.ehcache.Element
Sets whether the element is eternal.
setEternal(boolean) - Method in class net.sf.ehcache.management.CacheConfiguration
setEternal
setEternal(boolean) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setEternal
setEternal(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
setEternal
setEternal(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setEternal
setEvictionPolicy(Policy) - Method in class net.sf.ehcache.store.LruMemoryStore
Sets the eviction policy strategy.
setExpression(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the attribute expression.
setHeartBeatInterval(long) - Static method in class net.sf.ehcache.distribution.MulticastKeepaliveHeartbeatSender
Sets the heartbeat interval to something other than the default of 5000ms.
setImmediateShutdown(boolean) - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Sets whether the disposal of the instance will let the potential current key set being written to disk finish, or whether the shutdown will be immediate
setImmediateTimeout(boolean) - Method in class net.sf.ehcache.config.NonstopConfiguration
Set the value of immediateTimeout
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.store.disk.DiskStore
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.store.LruMemoryStore
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.store.MemoryOnlyStore
{inheritDoc}
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.store.MemoryStore
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.store.NullStore
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in interface net.sf.ehcache.store.Store
Sets the eviction policy strategy.
setInMemoryEvictionPolicy(Policy) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Sets the eviction policy strategy.
setInnerContent(String) - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Sets the inner content of this element
setInnerContent(String) - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Sets the inner content of this element
setKeys(boolean) - Method in class net.sf.ehcache.config.Searchable
Toggle searchable keys
setLeft(AATreeSet.Node<E>) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Set this node's left child.
setLeft(AATreeSet.Node<E>) - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Set this node's left child.
setLeft(AATreeSet.Node<Comparable>) - Method in class net.sf.ehcache.store.disk.ods.Region
 
setLevel(int) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Set this node's level.
setLevel(int) - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Set this node's level.
setLifespanDefaults(int, int, boolean) - Method in class net.sf.ehcache.Element
Set the default parameters of this element - those from its enclosing cache.
setListenFor(String) - Method in class net.sf.ehcache.config.CacheConfiguration.CacheEventListenerFactoryConfiguration
Used by BeanHandler to set the mode during parsing.
setLocalCacheEnabled(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Enable or disable the local cache
setLocalKeyCache(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Sets whether this cache should use an unclustered local key cache (usually should be false unless optimizing for a small read-only cache)

Defaults to false.

setLocalKeyCacheSize(int) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Sets maximum size of the local key cache (usually the size of the key set of the cache or cache partition).
setLogging(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Enables or disables logging for the cache

This property can be modified dynamically while the cache is operating.

setLoggingEnabled(boolean) - Method in class net.sf.ehcache.management.CacheConfiguration
setLoggingEnabled
setLoggingEnabled(boolean) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setLoggingEnabled
setLoggingEnabled(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
setLoggingEnabled
setLoggingEnabled(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setLoggingEnabled
setMaxBytesLocalDisk(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Setter for maxBytesOnDisk as a String.
setMaxBytesLocalDisk(Long) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the maximum amount of bytes the cache being configured will use on the OnDisk tier
setMaxBytesLocalDisk(String) - Method in class net.sf.ehcache.config.Configuration
Sets maximum amount of bytes the CacheManager will use on the Disk Tier.
setMaxBytesLocalDisk(Long) - Method in class net.sf.ehcache.config.Configuration
Sets maximum amount of bytes the CacheManager will use on the Disk Tier.
setMaxBytesLocalDisk(long) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMaxBytesLocalDisk
setMaxBytesLocalDisk(long) - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
setMaxBytesLocalDisk(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
setMaxBytesLocalDisk(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMaxBytesLocalDisk
setMaxBytesLocalDiskAsString(String) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMaxBytesLocalDisk
setMaxBytesLocalDiskAsString(String) - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
setMaxBytesLocalDiskAsString(String) - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
setMaxBytesLocalDiskAsString(String) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMaxBytesLocalDisk
setMaxBytesLocalHeap(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Setter for maxBytesLocalHeap as a String.
setMaxBytesLocalHeap(Long) - Method in class net.sf.ehcache.config.CacheConfiguration
Setter for maxBytesLocalHeap in bytes
setMaxBytesLocalHeap(String) - Method in class net.sf.ehcache.config.Configuration
Sets maximum amount of bytes the CacheManager will use on the Disk Tier.
setMaxBytesLocalHeap(Long) - Method in class net.sf.ehcache.config.Configuration
Sets the maximum amount of bytes the cache manager being configured will use on the OnHeap tier
setMaxBytesLocalHeap(long) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMaxBytesLocalHeap
setMaxBytesLocalHeap(long) - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
setMaxBytesLocalHeap(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
setMaxBytesLocalHeap(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMaxBytesLocalHeap
setMaxBytesLocalHeapAsString(String) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMaxBytesLocalHeap
setMaxBytesLocalHeapAsString(String) - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
setMaxBytesLocalHeapAsString(String) - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
 
setMaxBytesLocalHeapAsString(String) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMaxBytesLocalHeap
setMaxBytesLocalOffHeap(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Setter for maximum bytes off heap as a String.
setMaxBytesLocalOffHeap(Long) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the maximum amount of bytes the cache being configured will use on the OffHeap tier
setMaxBytesLocalOffHeap(String) - Method in class net.sf.ehcache.config.Configuration
Sets maximum amount of bytes the CacheManager will use on the OffHeap Tier.
setMaxBytesLocalOffHeap(Long) - Method in class net.sf.ehcache.config.Configuration
Sets maximum amount of bytes the CacheManager will use on the OffHeap Tier.
setMaxDepth(int) - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Sets the maximum depth the SizeOf engine can normally traverse
setMaxDepthExceededBehavior(String) - Method in class net.sf.ehcache.config.SizeOfPolicyConfiguration
Sets the behavior of the SizeOf engine when the max depth is reached
setMaxElementsInMemory(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Deprecated. use CacheConfiguration.setMaxEntriesLocalHeap(long)
setMaxElementsInMemory(int) - Method in class net.sf.ehcache.management.CacheConfiguration
Deprecated. use CacheConfiguration.setMaxEntriesLocalHeap(long)
setMaxElementsInMemory(int) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Deprecated. use CacheConfigurationMBean.setMaxEntriesLocalHeap(long)
setMaxElementsInMemory(int) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMaxElementsInMemory
setMaxElementsInMemory(int) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMaxElementsInMemory
setMaxElementsOnDisk(int) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the maximum number elements on Disk.
setMaxElementsOnDisk(int) - Method in class net.sf.ehcache.management.CacheConfiguration
Deprecated. use CacheConfiguration.setMaxEntriesLocalDisk(long)
setMaxElementsOnDisk(int) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Deprecated. use CacheConfigurationMBean.setMaxEntriesLocalDisk(long)
setMaxElementsOnDisk(int) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMaxElementsOnDisk
setMaxElementsOnDisk(int) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMaxElementsOnDisk
setMaxEntriesLocalDisk(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the maximum number elements on Disk.
setMaxEntriesLocalDisk(long) - Method in class net.sf.ehcache.management.CacheConfiguration
Maximum number of entries that may be stores in the local disk store.
setMaxEntriesLocalDisk(long) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Configured maximum number of entries for the local disk store.
setMaxEntriesLocalDisk(long) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMaxEntriesLocalDisk
setMaxEntriesLocalDisk(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMaxEntriesLocalDisk
setMaxEntriesLocalHeap(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the maximum objects to be held in local heap memory (0 = no limit).
setMaxEntriesLocalHeap(long) - Method in class net.sf.ehcache.management.CacheConfiguration
Maximum number of entries that may be stored in local heap memory store.
setMaxEntriesLocalHeap(long) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
Configured maximum number of entries for the local memory heap.
setMaxEntriesLocalHeap(long) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMaxEntriesLocalHeap
setMaxEntriesLocalHeap(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMaxEntriesLocalHeap
setMaxMemoryOffHeap(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the max off heap memory size allocated for this cache.
setMaxSize(long) - Method in class net.sf.ehcache.pool.impl.AbstractPool
Change the maximum size of the pool.
setMaxSize(long) - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
Sets the max size for this pool
setMaxSize(long) - Method in class net.sf.ehcache.pool.impl.UnboundedPool
Change the maximum size of the pool.
setMaxSize(long) - Method in interface net.sf.ehcache.pool.Pool
Change the maximum size of the pool.
setMaxSize(long) - Method in interface net.sf.ehcache.pool.PoolAccessor
Sets the max size for this pool
setMaxSize(long) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
setMaxWriteDelay(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Set the maximum number of seconds to wait before writing behind.
setMemoryStoreEvictionPolicy(Policy) - Method in class net.sf.ehcache.Cache
Sets the eviction policy strategy.
setMemoryStoreEvictionPolicy(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the eviction policy.
setMemoryStoreEvictionPolicy(String) - Method in class net.sf.ehcache.management.CacheConfiguration
setMemoryStoreEvictionPolicy
setMemoryStoreEvictionPolicy(String) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setMemoryStoreEvictionPolicy
setMemoryStoreEvictionPolicy(String) - Method in class net.sf.ehcache.management.sampled.SampledCache
setMemoryStoreEvictionPolicy
setMemoryStoreEvictionPolicy(String) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setMemoryStoreEvictionPolicy
setMemoryStoreEvictionPolicyFromObject(MemoryStoreEvictionPolicy) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the eviction policy.
setMimeType(String) - Method in class net.sf.ehcache.MimeTypeByteArray
 
setMinWriteDelay(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Set the minimum number of seconds to wait before writing behind.
setMonitoring(String) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to set the monitoring flag
setName(String) - Method in class net.sf.ehcache.Cache
Sets the cache name which will name.
setName(String) - Method in class net.sf.ehcache.CacheManager
Sets the name of the CacheManager.
setName(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the name of the cache.
setName(String) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to set the CacheManager name.
setName(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the attribute name
setName(String) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Sets the cache name which will name.
setName(String) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Sets the cache name which will name.
setName(String) - Method in interface net.sf.ehcache.Ehcache
Sets the cache name which will name.
setNodeBulkLoadEnabled(boolean) - Method in class net.sf.ehcache.Cache
Enable/disable bulk-load mode in this node for this cache.
setNodeBulkLoadEnabled(boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Enable/disable bulk-load mode in this node for this cache.
setNodeBulkLoadEnabled(boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Enable/disable bulk-load mode in this node for this cache.
setNodeBulkLoadEnabled(boolean) - Method in interface net.sf.ehcache.Ehcache
Enable/disable bulk-load mode in this node for this cache.
setNodeBulkLoadEnabled(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
Enabled/disable bulk-load mode for this node.
setNodeBulkLoadEnabled(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Enabled/disable bulk-load mode for this node.
setNodeCoherent(boolean) - Method in class net.sf.ehcache.Cache
Deprecated. use Cache.setNodeBulkLoadEnabled(boolean) instead
setNodeCoherent(boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Sets the cache in coherent or incoherent mode depending on the parameter on this node.
setNodeCoherent(boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Deprecated. Use EhcacheDecoratorAdapter.setNodeBulkLoadEnabled(boolean) instead
setNodeCoherent(boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Sets the cache in coherent or incoherent mode for the current node depending on the parameter.
setNodeCoherent(boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Sets the cache in coherent or incoherent mode for the current node depending on the parameter.
setNodeCoherent(boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Sets the cache in coherent or incoherent mode for the current node depending on the parameter.
setNodeCoherent(boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Sets the cache in coherent or incoherent mode for the current node depending on the parameter.
setNodeCoherent(boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Sets the cache in coherent or incoherent mode for the current node depending on the parameter.
setNodeCoherent(boolean) - Method in interface net.sf.ehcache.Ehcache
Deprecated. Use Ehcache.setNodeBulkLoadEnabled(boolean) instead
setNodeCoherent(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
Deprecated. use SampledCache.setNodeBulkLoadEnabled(boolean) instead
setNodeCoherent(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Deprecated. use SampledCacheMBean.setNodeBulkLoadEnabled(boolean) instead
setNodeCoherent(boolean) - Method in class net.sf.ehcache.store.AbstractStore
Sets the cache in coherent or incoherent mode for the current node depending on the parameter.
setNodeCoherent(boolean) - Method in interface net.sf.ehcache.store.Store
Sets the cache in coherent or incoherent mode for the current node depending on the parameter.
setNodeCoherent(boolean) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Sets the cache in coherent or incoherent mode for the current node depending on the parameter.
setNotifyListenersOnException(boolean) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Sets whether to notify listeners when an exception occurs on a writer operation.
setNumeratorValue(long) - Method in interface net.sf.ehcache.util.counter.sampled.SampledRateCounter
Sets the value of the numerator to the passed value
setNumeratorValue(long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
Sets the value of the numerator to the passed value
setOnDiskCapacity(int) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Set the maximum on-disk capacity for this factory.
setOperationsFilter(OperationsFilter) - Method in interface net.sf.ehcache.writer.writebehind.WriteBehind
Set the operations filter that should be used.
setOperationsFilter(OperationsFilter) - Method in class net.sf.ehcache.writer.writebehind.WriteBehindQueueManager
Set the operations filter that should be used.
setOptional(boolean) - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
Sets optional or not
setOptional(boolean) - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Sets this attribute to optional or not
setOptional(boolean) - Method in interface net.sf.ehcache.config.generator.model.NodeElement
Sets optional or not
setOptional(boolean) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Sets this attribute to optional or not
setOrphanEviction(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Sets whether this cache should perform orphan eviction (usually should be true).
setOrphanEvictionPeriod(int) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Set how often this cache should perform orphan eviction (measured in regular eviction periods).
setOverflowToDisk(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets whether elements can overflow to disk when the in-memory cache has reached the set limit.
setOverflowToDisk(boolean) - Method in class net.sf.ehcache.management.CacheConfiguration
setOverflowToDisk
setOverflowToDisk(boolean) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setOverflowToDisk
setOverflowToDisk(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
setOverflowToDisk
setOverflowToDisk(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setOverflowToDisk
setOverflowToOffHeap(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Enables or disables offheap store for the cache.
setPath(String) - Method in class net.sf.ehcache.config.DiskStoreConfiguration
Translates and sets the path.
setPinned(Object, boolean) - Method in class net.sf.ehcache.Cache
Mark the key as pinned or not.
setPinned(Object, boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Mark the key as pinned or not.
setPinned(Object, boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Mark the key as pinned or not.
setPinned(Object, boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Mark the key as pinned or not
setPinned(Object, boolean) - Method in interface net.sf.ehcache.Ehcache
Mark the key as pinned or not.
setPinned(Object, boolean) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
setPinned(Object, boolean) - Method in class net.sf.ehcache.store.disk.DiskStore
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.store.FrontEndCacheTier
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.store.LegacyStoreWrapper
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.store.LruMemoryStore
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.store.MemoryStore
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.store.NullStore
Mark the key as pinned or not
setPinned(Object, boolean) - Method in interface net.sf.ehcache.store.Store
Mark the key as pinned or not
setPinned(Object, boolean) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Mark the key as pinned or not
setPinning(Object, boolean) - Method in class net.sf.ehcache.store.LruMemoryStore.SpoolingLinkedHashMap
Mark the key as pinned or not
setProperties(String) - Method in class net.sf.ehcache.config.FactoryConfiguration
Sets the configuration properties.
setProperties(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the extractor properties
setProperties(String) - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Set the properties
setProperties(Properties) - Method in class net.sf.ehcache.transaction.manager.DefaultTransactionManagerLookup
Setter to the properties properties.
setProperties(Properties) - Method in interface net.sf.ehcache.transaction.manager.TransactionManagerLookup
Setter to the properties properties.
setPropertySeparator(String) - Method in class net.sf.ehcache.config.FactoryConfiguration
Setter
setPropertySeparator(String) - Method in class net.sf.ehcache.config.SearchAttribute
Set the extractor properties separator
setPropertySeparator(String) - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Set the property separator
setRateLimitPerSecond(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Sets the maximum number of write operations to allow per second when CacheWriterConfiguration.writeBatching is enabled.
setRegionCacheEnabled(String, boolean) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Enables/disables a particular region
setRegionCacheEnabled(String, boolean) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Enables/disables a particular region
setRegionCacheEnabled(String, boolean) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Enables/disables a particular region
setRegionCacheLoggingEnabled(String, boolean) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Enable/Disable logging for the input cache region
setRegionCacheLoggingEnabled(String, boolean) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Enable/Disable logging for the input cache region
setRegionCacheLoggingEnabled(String, boolean) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Enable/Disable logging for the input cache region
setRegionCacheMaxTTISeconds(String, int) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Sets the time to idle for the input cache region
setRegionCacheMaxTTISeconds(String, int) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Sets the time to idle for the input cache region
setRegionCacheMaxTTISeconds(String, int) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Sets the time to idle for the input cache region
setRegionCacheMaxTTLSeconds(String, int) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Sets the time to live for the input cache region
setRegionCacheMaxTTLSeconds(String, int) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Sets the time to live for the input cache region
setRegionCacheMaxTTLSeconds(String, int) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Sets the time to live for the input cache region
setRegionCachesEnabled(boolean) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Enable/disable all the cache regions.
setRegionCachesEnabled(boolean) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Enable/disable all the cache regions.
setRegionCachesEnabled(boolean) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
 
setRegionCacheTargetMaxInMemoryCount(String, int) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Sets the maxElementsInMemory of the input cache region
setRegionCacheTargetMaxInMemoryCount(String, int) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Sets the maxElementsInMemory of the input cache region
setRegionCacheTargetMaxInMemoryCount(String, int) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Sets the maxElementsInMemory of the input cache region
setRegionCacheTargetMaxTotalCount(String, int) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Sets the maxElementsOnDisk of the input cache region
setRegionCacheTargetMaxTotalCount(String, int) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Sets the maxElementsOnDisk of the input cache region
setRegionCacheTargetMaxTotalCount(String, int) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Sets the maxElementsOnDisk of the input cache region
setRejoin(boolean) - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Set rejoin value
setRetryAttemptDelaySeconds(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Sets the number of seconds to wait before retrying an failed operation.
setRetryAttempts(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Sets the number of times the operation is retried in the CacheWriter, this happens after the original operation.
setRight(AATreeSet.Node<E>) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet.AbstractTreeNode
Set this node's right child.
setRight(AATreeSet.Node<E>) - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Set this node's right child.
setRight(AATreeSet.Node<Comparable>) - Method in class net.sf.ehcache.store.disk.ods.Region
 
setRollbackOnly() - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Mark the context for rollback
setRollbackOnly() - Method in class net.sf.ehcache.TransactionController
Mark the transaction bound to the current thread for rollback only
setSampledStatisticsEnabled(boolean) - Method in class net.sf.ehcache.Cache
Enable/disable sampled statistics collection.
setSampledStatisticsEnabled(boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Enable/disable sampled statistics collection.
setSampledStatisticsEnabled(boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Enable/disable sampled statistics collection.
setSampledStatisticsEnabled(boolean) - Method in interface net.sf.ehcache.Ehcache
Enable/disable sampled statistics collection.
setSnapshotOnDispose(boolean) - Method in class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Configures the Loader to take a snapshot when it is being disposed
setSource(ConfigurationSource) - Method in class net.sf.ehcache.config.Configuration
Sets the configuration source.
setStatistics(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets whether the cache's statistics are enabled.
setStatisticsAccuracy(int) - Method in class net.sf.ehcache.Cache
Sets the statistics accuracy.
setStatisticsAccuracy(int) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Sets the statistics accuracy.
setStatisticsAccuracy(int) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Sets the statistics accuracy.
setStatisticsAccuracy(int) - Method in interface net.sf.ehcache.Ehcache
Sets the statistics accuracy.
setStatisticsAccuracy(int) - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Sets the statistics accuracy.
setStatisticsAccuracy(int) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Sets the statistics accuracy.
setStatisticsAccuracy(int) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Sets the statistics accuracy.
setStatisticsAccuracy(int) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Sets the statistics accuracy.
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.Cache
Enable/disable statistics collection.
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Enable/disable statistics collection.
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Enable/disable statistics collection.
setStatisticsEnabled(boolean) - Method in interface net.sf.ehcache.Ehcache
Enable/disable statistics collection.
setStatisticsEnabled(boolean) - Method in interface net.sf.ehcache.hibernate.management.api.EhcacheStats
Enable/Disable statistics collection for all cache of the related session-factory
setStatisticsEnabled(boolean) - Method in interface net.sf.ehcache.hibernate.management.api.HibernateStats
Enable/Disable statistics collection
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheHibernate
Enable/Disable statistics collection for all cache of the related session-factory
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.hibernate.management.impl.EhcacheStatsImpl
Enable/Disable statistics collection for all cache of the related session-factory
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.hibernate.management.impl.HibernateStatsImpl
Enable/Disable statistics collection
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.hibernate.management.impl.NullHibernateStats
Enable/Disable statistics collection
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCache
Controls the statistics.
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Enables/disables each contained cache
setStatisticsEnabled(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Enables/disables each contained cache
setStatisticsEnabled(boolean) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
Controls the statistics.
setStatisticsEnabled(boolean) - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Enabled/Disabled statistics
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Enabled/Disabled statistics
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Enabled/Disabled statistics
setStatisticsEnabled(boolean) - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Enabled/Disabled statistics
setStorageStrategy(String) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Converts the storageStrategy string argument to uppercase and looks up enum constant in StorageStrategy.
setStore(String) - Method in class net.sf.ehcache.config.PinningConfiguration
Set the store scope
setSynchronousWrites(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Set the value for synchronous-write
setTimeoutMillis(long) - Method in class net.sf.ehcache.config.NonstopConfiguration
Set the value of timeoutMillis
setTimeoutMillis(int) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Sets the time to wait to acquire a lock.
setTimeToIdle(int) - Method in class net.sf.ehcache.Element
Sets time to idle
setTimeToIdleSeconds(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the time to idle for an element before it expires.
setTimeToIdleSeconds(long) - Method in class net.sf.ehcache.management.CacheConfiguration
setTimeToIdleSeconds
setTimeToIdleSeconds(long) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setTimeToIdleSeconds
setTimeToIdleSeconds(long) - Method in class net.sf.ehcache.management.sampled.SampledCache
setTimeToIdleSeconds
setTimeToIdleSeconds(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setTimeToIdleSeconds
setTimeToLive(int) - Method in class net.sf.ehcache.Element
Sets time to Live
setTimeToLiveSeconds(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the time to idle for an element before it expires.
setTimeToLiveSeconds(long) - Method in class net.sf.ehcache.management.CacheConfiguration
setTimeToLiveSeconds
setTimeToLiveSeconds(long) - Method in interface net.sf.ehcache.management.CacheConfigurationMBean
setTimeToLiveSeconds
setTimeToLiveSeconds(long) - Method in class net.sf.ehcache.management.sampled.SampledCache
setTimeToLiveSeconds
setTimeToLiveSeconds(long) - Method in interface net.sf.ehcache.management.sampled.SampledCacheMBean
setTimeToLiveSeconds
settings - Variable in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Hibernate settings associated with the persistence unit.
setTransactionalMode(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets the transactionalMode
setTransactionManagerLookup(TransactionManagerLookup) - Method in class net.sf.ehcache.Cache
Sets the TransactionManagerLookup that needs to be used for this cache to lookup the TransactionManager This needs to be set before Cache.initialise() is called
setTransactionManagerLookup(TransactionManagerLookup) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
This class is used to access the transaction manager used during XA.
setTransactionManagerLookup(TransactionManagerLookup) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
This class is used to access the transaction manager used during XA.
setTransactionManagerLookup(TransactionManagerLookup) - Method in interface net.sf.ehcache.Ehcache
This class is used to access the transaction manager used during XA.
setTransactionTimeout(int) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
setType(String) - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Set the type of timeout behavior
setUnderlyingCacheCluster(CacheCluster) - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Set the underlying cache
setUpdateCheck(boolean) - Method in class net.sf.ehcache.config.Configuration
Allows BeanHandler to set the updateCheck flag.
setupFor(CacheManager) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets up the CacheConfiguration for runtime consumption, also registers this cache configuration with the cache manager's configuration
setupFor(CacheManager, boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Sets up the CacheConfiguration for runtime consumption
setupFor(CacheManager, String) - Method in class net.sf.ehcache.config.Configuration
Freezes part of the configuration that need to be, and runs validation checks on the Configuration.
setUrl(String) - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Set url
setValue(String) - Method in interface net.sf.ehcache.config.generator.model.NodeAttribute
Setter for value
setValue(String) - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Setter for value
setValue(byte[]) - Method in class net.sf.ehcache.MimeTypeByteArray
 
setValue(long) - Method in interface net.sf.ehcache.util.counter.Counter
Sets the value of the counter to the supplied value
setValue(long) - Method in class net.sf.ehcache.util.counter.CounterImpl
Sets the value of the counter to the supplied value
setValue(long, long) - Method in interface net.sf.ehcache.util.counter.sampled.SampledRateCounter
Sets the values of the numerator and denominator to the passed values
setValue(long, long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
Sets the values of the numerator and denominator to the passed values
setValue(long) - Method in class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl
throws UnsupportedOperationException
setValueMode(String) - Method in class net.sf.ehcache.config.TerracottaConfiguration
Converts the valueMode string argument to uppercase and looks up enum constant in ValueMode.
setValues(boolean) - Method in class net.sf.ehcache.config.Searchable
Toggle searchable values
setVersion(long) - Method in class net.sf.ehcache.Element
Sets the version attribute of the ElementAttributes object.
setWriteBatching(boolean) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Sets whether to batch write operations.
setWriteBatchSize(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Sets the number of operations to include in each batch when CacheWriterConfiguration.writeBatching is enabled.
setWriteBehindConcurrency(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Configures the amount of thread/bucket pairs WriteBehind should use
setWriteBehindMaxQueueSize(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Configures the maximum amount of operations to be on the waiting queue, before it blocks
setWriteCoalescing(boolean) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Sets whether to use write coalescing.
setWriteMode(String) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
Converts the valueMode string argument to uppercase and looks up enum constant in WriteMode.
SHORT_DELAY - Static variable in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
One tenth of a second, in ms
shortName - Variable in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
region short name
shortName - Variable in class net.sf.ehcache.hibernate.management.impl.CollectionStats
shortName
shortName - Variable in class net.sf.ehcache.hibernate.management.impl.EntityStats
shortName
shouldDeliver(boolean) - Method in enum net.sf.ehcache.event.NotificationScope
Determine whether an event should be delivered under this notification scope.
shrinkDataFile() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Shrink this store's data file down to a minimal size for its contents.
shutdown() - Method in class net.sf.ehcache.CacheManager
Shuts down the CacheManager.
shutdown(CacheManager) - Method in class net.sf.ehcache.constructs.nonstop.CacheManagerExecutorServiceFactory
Shuts down the NonstopExecutorService associated with the CacheManager
shutdown() - Method in interface net.sf.ehcache.constructs.nonstop.NonstopExecutorService
Shut down this executor service
shutdown(CacheManager) - Method in interface net.sf.ehcache.constructs.nonstop.NonstopExecutorServiceFactory
Shuts down the NonstopExecutorService associated with the CacheManager
shutdown() - Method in class net.sf.ehcache.constructs.nonstop.NonstopExecutorServiceImpl
Shut down this executor service
shutdown() - Method in class net.sf.ehcache.management.CacheManager
Shuts down the CacheManager.
shutdown() - Method in interface net.sf.ehcache.management.CacheManagerMBean
Shuts down the CacheManager.
shutdown() - Method in class net.sf.ehcache.management.sampled.SampledCacheManager
Shuts down the CacheManager.
shutdown() - Method in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
Shuts down the CacheManager.
shutdown() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Shuts down this disk factory.
shutdown() - Method in interface net.sf.ehcache.terracotta.ClusteredInstanceFactory
Cleans up any resources left behind after the shutdown of the associated CacheManager
shutdown() - Method in class net.sf.ehcache.terracotta.ClusteredInstanceFactoryWrapper
Cleans up any resources left behind after the shutdown of the associated CacheManager
shutdown() - Method in class net.sf.ehcache.terracotta.TerracottaClient
Shuts down the client
shutdown() - Static method in class net.sf.ehcache.transaction.xa.processor.XARequestProcessor
Release resources shared by all XARequestProcessors
shutdown() - Method in class net.sf.ehcache.transaction.xa.processor.XAThreadPool
Shutdown the thread pool and release all resources
shutdown() - Method in interface net.sf.ehcache.util.counter.CounterManager
Shuts down this counter manager
shutdown() - Method in class net.sf.ehcache.util.counter.CounterManagerImpl
Shuts down this counter manager
shutdown() - Method in interface net.sf.ehcache.util.counter.sampled.SampledCounter
Shutdown this counter
shutdown() - Method in class net.sf.ehcache.util.counter.sampled.SampledCounterImpl
Shutdown this counter
shutdownCounter(Counter) - Method in interface net.sf.ehcache.util.counter.CounterManager
Shuts down the counter
shutdownCounter(Counter) - Method in class net.sf.ehcache.util.counter.CounterManagerImpl
Shuts down the counter
shutdownHook - Variable in class net.sf.ehcache.CacheManager
The shutdown hook thread for CacheManager.
ShutdownListener - Class in net.sf.ehcache.constructs.web
A ServletContextListener that shutsdown CacheManager.
ShutdownListener() - Constructor for class net.sf.ehcache.constructs.web.ShutdownListener
 
shutdownNow() - Method in class net.sf.ehcache.constructs.nonstop.NonstopThreadPool
Shuts down the thread pool
SimpleNodeAttribute - Class in net.sf.ehcache.config.generator.model
Implementation of the NodeAttribute interface
SimpleNodeAttribute(String) - Constructor for class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Constructor accepting the name of the attribute
SimpleNodeAttribute(String, Enum) - Constructor for class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Constructor accepting name and Enum value of the attribute
SimpleNodeAttribute(String, int) - Constructor for class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Constructor accepting name and int value of the attribute
SimpleNodeAttribute(String, long) - Constructor for class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Constructor accepting name and long value of the attribute
SimpleNodeAttribute(String, boolean) - Constructor for class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Constructor accepting name and boolean value of the attribute
SimpleNodeAttribute(String, String) - Constructor for class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
Constructor accepting name and String value of the attribute
SimpleNodeElement - Class in net.sf.ehcache.config.generator.model
A concrete class extending the AbstractNodeElement class
SimpleNodeElement(NodeElement, String) - Constructor for class net.sf.ehcache.config.generator.model.SimpleNodeElement
Constructor accepting the parent and name of this element
SingleOperation - Interface in net.sf.ehcache.writer.writebehind.operations
Interface to implement single operations that are performed with write-behind
SingleOperationType - Enum in net.sf.ehcache.writer.writebehind.operations
Enum class to provide distinct operation types for each single operation.
SingletonEhCacheProvider - Class in net.sf.ehcache.hibernate
Deprecated. 
SingletonEhCacheProvider() - Constructor for class net.sf.ehcache.hibernate.SingletonEhCacheProvider
Deprecated.  
SingletonEhCacheRegionFactory - Class in net.sf.ehcache.hibernate
A singleton EhCacheRegionFactory implementation.
SingletonEhCacheRegionFactory(Properties) - Constructor for class net.sf.ehcache.hibernate.SingletonEhCacheRegionFactory
Returns a representation of the singleton EhCacheRegionFactory
size() - Method in class net.sf.ehcache.constructs.nonstop.concurrency.NonStopCacheKeySet
Size - Class in net.sf.ehcache.pool
Holder for the size calculated by the SizeOf engine
Size(long, boolean) - Constructor for class net.sf.ehcache.pool.Size
Constructor
size() - Method in class net.sf.ehcache.search.impl.ResultsImpl
Results size
size() - Method in class net.sf.ehcache.search.NullResults
Results size
size() - Method in interface net.sf.ehcache.search.Results
Results size
size() - Method in class net.sf.ehcache.store.CacheKeySet
Sums the size of all sets wrapped by this one, so this will not account for duplicated keys.
size() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
size() - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
 
size() - Method in class net.sf.ehcache.store.disk.ods.Region
Returns the size of this range (the number of values within its bounds).
size() - Method in class net.sf.ehcache.util.LargeCollection
size() - Method in class net.sf.ehcache.util.SetAsList
sizeOf(Object, Object, Object) - Method in class net.sf.ehcache.pool.impl.DefaultSizeOfEngine
Size an element
sizeOf(Object) - Method in class net.sf.ehcache.pool.sizeof.AgentSizeOf
 
sizeOf(Object) - Method in class net.sf.ehcache.pool.sizeof.ReflectionSizeOf
Calculates the size in memory (heap) of the instance passed in, not navigating the down graph
SizeOf - Class in net.sf.ehcache.pool.sizeof
Abstract sizeOf for Java.
SizeOf(SizeOfFilter, boolean) - Constructor for class net.sf.ehcache.pool.sizeof.SizeOf
Builds a new SizeOf that will filter fields according to the provided filter
sizeOf(Object) - Method in class net.sf.ehcache.pool.sizeof.SizeOf
Calculates the size in memory (heap) of the instance passed in, not navigating the down graph
sizeOf(Object) - Method in class net.sf.ehcache.pool.sizeof.UnsafeSizeOf
Calculates the size in memory (heap) of the instance passed in, not navigating the down graph
sizeOf(Object, Object, Object) - Method in interface net.sf.ehcache.pool.SizeOfEngine
Size an element
sizeOf(Object, Object, Object) - Method in class net.sf.ehcache.store.disk.DiskSizeOfEngine
Size an element
sizeOfEngine - Variable in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
SizeOfEngine used by the accessor.
SizeOfEngine - Interface in net.sf.ehcache.pool
SizeOf engines are used to calculate the size of elements stored in poolable stores.
SizeOfFilter - Interface in net.sf.ehcache.pool.sizeof.filter
Filter to filter types or fields of object graphs passed to a SizeOf engine
sizeOfPolicy(SizeOfPolicyConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder to set the SizeOfPolicyConfiguration for this cache.
sizeOfPolicy(SizeOfPolicyConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder to set the default SizeOfPolicyConfiguration for this cache manager.
SizeOfPolicyConfiguration - Class in net.sf.ehcache.config
Class to hold the SizeOf policy configuration.
SizeOfPolicyConfiguration() - Constructor for class net.sf.ehcache.config.SizeOfPolicyConfiguration
 
SizeOfPolicyConfiguration.MaxDepthExceededBehavior - Enum in net.sf.ehcache.config
Enum of the possible behaviors of the SizeOf engine when the max depth is exceeded
SizeOfPolicyConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
Element representing the SizeOfPolicyConfiguration
SizeOfPolicyConfigurationElement(ConfigurationElement, SizeOfPolicyConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.SizeOfPolicyConfigurationElement
Construtor accepting the parent and the SizeOfPolicyConfiguration
SizeOfPolicyConfigurationElement(NodeElement, SizeOfPolicyConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.SizeOfPolicyConfigurationElement
Construtor accepting the element and the SizeOfPolicyConfiguration
SoftLock - Interface in net.sf.ehcache.transaction
A soft lock is used to lock elements in transactional stores
SoftLockFactory - Interface in net.sf.ehcache.transaction
A factory for SoftLocks
source(ConfigurationSource) - Method in class net.sf.ehcache.config.Configuration
Builder to set the configuration source.
sourceIterator() - Method in class net.sf.ehcache.util.LargeCollection
Iterator of initial set of entries.
sourceSize() - Method in class net.sf.ehcache.util.LargeCollection
Initial set of entries size.
spoolAllToDisk() - Method in class net.sf.ehcache.store.LruMemoryStore
Spools all elements to disk, in preparation for shutdown.
spoolToDisk(Element) - Method in class net.sf.ehcache.store.LruMemoryStore
Puts the element in the DiskStore.
stale(Date) - Method in class net.sf.ehcache.distribution.ManualRMICacheManagerPeerProvider
Whether the entry should be considered stale.
stale(Date) - Method in class net.sf.ehcache.distribution.MulticastRMICacheManagerPeerProvider
Whether the entry should be considered stale.
stale(Date) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
Whether the entry should be considered stale.
start(Properties) - Method in class net.sf.ehcache.hibernate.EhCacheProvider
Deprecated. Callback to perform any necessary initialization of the underlying cache implementation during SessionFactory construction.
start(Settings, Properties) - Method in class net.sf.ehcache.hibernate.EhCacheRegionFactory
start(Properties) - Method in class net.sf.ehcache.hibernate.SingletonEhCacheProvider
Deprecated. Callback to perform any necessary initialization of the underlying cache implementation during SessionFactory construction.
start(Settings, Properties) - Method in class net.sf.ehcache.hibernate.SingletonEhCacheRegionFactory
start() - Method in class net.sf.ehcache.store.disk.ods.Region
Returns the start of this range (inclusive).
start(Xid, int) - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
start(CacheWriter) - Method in interface net.sf.ehcache.writer.writebehind.WriteBehind
Start the write behind queue with a cache writer
start(CacheWriter) - Method in class net.sf.ehcache.writer.writebehind.WriteBehindQueueManager
Start the write behind queue with a cache writer
startAttributes(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Starts visiting the attributes of the element.
startAttributes(NodeElement) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Starts visiting the attributes of the element.
startChildren(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Starts visiting children of the element.
startChildren(NodeElement) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Starts visiting children of the element.
startElement(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Starts visiting an element.
startElement(NodeElement) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Starts visiting an element.
startRegistry() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Start the rmiregistry.
statistics(boolean) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets whether the cache's statistics are enabled.
Statistics - Class in net.sf.ehcache
An immutable Cache statistics implementation

This is like a value object, with the added ability to clear cache statistics on the cache.

Statistics(Ehcache, int, long, long, long, long, long, long, long, long, long, float, long, long, long, long, long, long, long) - Constructor for class net.sf.ehcache.Statistics
Creates a new statistics object, associated with a Cache
STATISTICS_ACCURACY_BEST_EFFORT - Static variable in class net.sf.ehcache.Statistics
Best efforts accuracy setting.
STATISTICS_ACCURACY_GUARANTEED - Static variable in class net.sf.ehcache.Statistics
Guaranteed accuracy setting.
STATISTICS_ACCURACY_NONE - Static variable in class net.sf.ehcache.Statistics
Fast but not accurate setting.
STATISTICS_ENABLED - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
STATISTICS_ENABLED
STATISTICS_RESET - Static variable in interface net.sf.ehcache.management.sampled.SampledCacheManagerMBean
STATISTICS_RESET
status - Variable in class net.sf.ehcache.CacheManager
Status of the Cache Manager
status - Variable in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
status.
status - Variable in class net.sf.ehcache.distribution.RMISynchronousCacheReplicator
The status of the replicator.
Status - Class in net.sf.ehcache
A pre JDK1.5 compatible enum class to indicate the status of a CacheManager or Cache.
status - Variable in class net.sf.ehcache.store.LruMemoryStore
status.
STATUS_ALIVE - Static variable in class net.sf.ehcache.Status
The cache is alive.
STATUS_SHUTDOWN - Static variable in class net.sf.ehcache.Status
The cache is shudown.
STATUS_UNINITIALISED - Static variable in class net.sf.ehcache.Status
The cache is uninitialised.
stop() - Method in class net.sf.ehcache.hibernate.EhCacheProvider
Deprecated. Callback to perform any necessary cleanup of the underlying cache implementation during SessionFactory.close().
stop() - Method in class net.sf.ehcache.hibernate.EhCacheRegionFactory
stop() - Method in class net.sf.ehcache.hibernate.SingletonEhCacheProvider
Deprecated. Callback to perform any necessary cleanup of the underlying cache implementation during SessionFactory.close().
stop() - Method in class net.sf.ehcache.hibernate.SingletonEhCacheRegionFactory
stop() - Method in interface net.sf.ehcache.writer.writebehind.WriteBehind
Stop the coordinator and all the internal data structures.
stop() - Method in class net.sf.ehcache.writer.writebehind.WriteBehindQueueManager
Stop the coordinator and all the internal data structures.
stopRegistry() - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Stop the rmiregistry if it was started by this class.
storageStrategy(String) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
storageStrategy(TerracottaConfiguration.StorageStrategy) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
store(String) - Method in class net.sf.ehcache.config.PinningConfiguration
Set the lowest store from which elements must not be evicted from
store(PinningConfiguration.Store) - Method in class net.sf.ehcache.config.PinningConfiguration
Set the lowest store from which elements must not be evicted from
Store - Class in net.sf.ehcache.management
Wrapper class for store specific dynamic mbeans.
store - Variable in class net.sf.ehcache.store.disk.DiskStorageFactory
The store bound to this factory.
Store - Interface in net.sf.ehcache.store
This is the interface for all stores.
STORE_TYPE - Static variable in class net.sf.ehcache.management.sampled.SampledEhcacheMBeans
Type used for store mbean
storedObject(Element) - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
Return an object of the kind which will be stored when the element is going to be inserted
StoreListener - Interface in net.sf.ehcache.store
 
StorePutCommand - Class in net.sf.ehcache.transaction.xa.commands
Represents a Store.put(net.sf.ehcache.Element) put} operation to be executed on a Store.
StorePutCommand(Element, Element) - Constructor for class net.sf.ehcache.transaction.xa.commands.StorePutCommand
Create a StorePutCommand
StoreQuery - Interface in net.sf.ehcache.store
An immutable query that a Store can execute
StoreQuery.Ordering - Interface in net.sf.ehcache.store
An attribute / direction ordering pair
StoreRemoveCommand - Class in net.sf.ehcache.transaction.xa.commands
Represents a remove operation to be executed on a Store.
StoreRemoveCommand(Object, Element) - Constructor for class net.sf.ehcache.transaction.xa.commands.StoreRemoveCommand
Create a StoreRemoveCommand
StoreUpdateException - Exception in net.sf.ehcache.store.disk
Exception thrown by the Store when the writer fails.
StoreUpdateException(RuntimeException, boolean) - Constructor for exception net.sf.ehcache.store.disk.StoreUpdateException
Constructor
StrictlyBoundedPool - Class in net.sf.ehcache.pool.impl
A pool which strictly obeys to its bound: it will never allow the accessors to consume more bytes than what has been configured.
StrictlyBoundedPool(long, PoolEvictor<PoolableStore>, SizeOfEngine) - Constructor for class net.sf.ehcache.pool.impl.StrictlyBoundedPool
Create a StrictlyBoundedPool instance
StripedReadWriteLock - Interface in net.sf.ehcache.concurrent
 
StripedReadWriteLockProvider - Interface in net.sf.ehcache.store
Provider for StripedReadWriteLock that need to match a certain spreading function
StripedReadWriteLockSync - Class in net.sf.ehcache.concurrent
Provides a number of Sync which allow fine-grained concurrency.
StripedReadWriteLockSync() - Constructor for class net.sf.ehcache.concurrent.StripedReadWriteLockSync
Constructs a striped mutex with the default 2048 stripes.
StripedReadWriteLockSync(int) - Constructor for class net.sf.ehcache.concurrent.StripedReadWriteLockSync
Constructs a striped mutex with the default 2048 stripes.
subList(int, int) - Method in class net.sf.ehcache.util.SetAsList
Does not support List methods UnsupportedOperationException.
submit(Callable<T>) - Method in class net.sf.ehcache.constructs.nonstop.NonstopThreadPool
Submit a callable task to be executed by the thread pool
subSet(T, T) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
sum(Attribute<?>) - Static method in class net.sf.ehcache.search.aggregator.Aggregators
Construct a sum aggregator
Sum - Class in net.sf.ehcache.search.aggregator
Sums the results

Sum can be used with most numeric types

Sum(Attribute<?>) - Constructor for class net.sf.ehcache.search.aggregator.Sum
 
sum() - Method in class net.sf.ehcache.search.Attribute
Request a sum aggregation of this attribute
supportsAgentSizeOf() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Whether the jvm can support AgentSizeOf implementation.
supportsReflectionSizeOf() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Whether the jvm can support ReflectionSizeOf implementation.
supportsUnsafeSizeOf() - Method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Whether the jvm can support UnsafeSizeOf implementation.
swapPayload(AATreeSet.Node<E>) - Method in interface net.sf.ehcache.store.disk.ods.AATreeSet.Node
Swap the payload objects between this node and the supplied node.
swapPayload(AATreeSet.Node<Comparable>) - Method in class net.sf.ehcache.store.disk.ods.Region
Swap the payload objects between this node and the supplied node.
Sync - Interface in net.sf.ehcache.concurrent
 
synchronousWrites(boolean) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 

T

tailSet(T) - Method in class net.sf.ehcache.store.disk.ods.AATreeSet
TaskNotSubmittedTimeoutException - Exception in net.sf.ehcache.constructs.nonstop
Subclass of TimeoutException.
TaskNotSubmittedTimeoutException() - Constructor for exception net.sf.ehcache.constructs.nonstop.TaskNotSubmittedTimeoutException
Default constructor
TaskNotSubmittedTimeoutException(String) - Constructor for exception net.sf.ehcache.constructs.nonstop.TaskNotSubmittedTimeoutException
Constructor accepting a message
TaskNotSubmittedTimeoutException(int) - Constructor for exception net.sf.ehcache.constructs.nonstop.TaskNotSubmittedTimeoutException
Constructor accepting number of attempts made when this exception happened
TaskNotSubmittedTimeoutException(String, int) - Constructor for exception net.sf.ehcache.constructs.nonstop.TaskNotSubmittedTimeoutException
Constructor accepting message and number of attempts made
terracotta(TerracottaConfiguration) - Method in class net.sf.ehcache.config.CacheConfiguration
 
terracotta(TerracottaClientConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder method to Terracotta capabilities to the cache manager through a dedicated configuration, this can only be used once.
TerracottaBootstrapCacheLoader - Class in net.sf.ehcache.terracotta
A BootstrapCacheLoader that will load Elements into a Terracotta clustered cache, based on a previously snapshotted key set.
TerracottaBootstrapCacheLoader(boolean, String, boolean) - Constructor for class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Constructor
TerracottaBootstrapCacheLoader(boolean, String, long) - Constructor for class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Constructor
TerracottaBootstrapCacheLoader(boolean, String, long, boolean) - Constructor for class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoader
Constructor
TerracottaBootstrapCacheLoaderFactory - Class in net.sf.ehcache.terracotta
 
TerracottaBootstrapCacheLoaderFactory() - Constructor for class net.sf.ehcache.terracotta.TerracottaBootstrapCacheLoaderFactory
 
TerracottaCacheCluster - Class in net.sf.ehcache.terracotta
CacheCluster implementation that delegates to an underlying cache cluster.
TerracottaCacheCluster() - Constructor for class net.sf.ehcache.terracotta.TerracottaCacheCluster
 
TerracottaCacheEventReplication - Class in net.sf.ehcache.event
Creates a wrapper for sending out cache events through the Terracotta cluster
TerracottaCacheEventReplication() - Constructor for class net.sf.ehcache.event.TerracottaCacheEventReplication
 
TerracottaCacheEventReplicationFactory - Class in net.sf.ehcache.event
Factory for TerracottaCacheEventReplication instances
TerracottaCacheEventReplicationFactory() - Constructor for class net.sf.ehcache.event.TerracottaCacheEventReplicationFactory
 
TerracottaClient - Class in net.sf.ehcache.terracotta
Class encapsulating the idea of a Terracotta client.
TerracottaClient(CacheManager, TerracottaClientRejoinListener, TerracottaClientConfiguration) - Constructor for class net.sf.ehcache.terracotta.TerracottaClient
Constructor accepting the TerracottaClientRejoinListener and the TerracottaClientConfiguration
TerracottaClientConfiguration - Class in net.sf.ehcache.config
Holds the Terracotta configuration for a particular client
TerracottaClientConfiguration() - Constructor for class net.sf.ehcache.config.TerracottaClientConfiguration
 
TerracottaClientRejoinListener - Interface in net.sf.ehcache.terracotta
Interface for executing tasks when TerracottaClient rejoins cluster
TerracottaConfigConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the TerracottaClientConfiguration
TerracottaConfigConfigurationElement(NodeElement, TerracottaClientConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.TerracottaConfigConfigurationElement
Constructor accepting the parent and the TerracottaClientConfiguration
terracottaConfiguration - Variable in class net.sf.ehcache.config.CacheConfiguration
The TerracottaConfiguration.
TerracottaConfiguration - Class in net.sf.ehcache.config
Class to hold the Terracotta configuration - either a pointer to the real config or a container for embedded config.
TerracottaConfiguration() - Constructor for class net.sf.ehcache.config.TerracottaConfiguration
 
TerracottaConfiguration.Consistency - Enum in net.sf.ehcache.config
Enum for various consistency settings
TerracottaConfiguration.StorageStrategy - Enum in net.sf.ehcache.config
Represents whether keys/values are to be stored in the local vm or the Terracotta server
TerracottaConfiguration.ValueMode - Enum in net.sf.ehcache.config
Represents whether values are stored with serialization in the clustered store or through Terracotta clustered identity.
TerracottaConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the TerracottaConfiguration
TerracottaConfigurationElement(NodeElement, TerracottaConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.TerracottaConfigurationElement
Constructor accepting the parent and the TerracottaConfiguration
TerracottaNotRunningException - Exception in net.sf.ehcache.terracotta
Exception thrown when using Terracotta clustered operations and Terracotta is not running
TerracottaNotRunningException() - Constructor for exception net.sf.ehcache.terracotta.TerracottaNotRunningException
Default Constructor
TerracottaNotRunningException(String, Throwable) - Constructor for exception net.sf.ehcache.terracotta.TerracottaNotRunningException
Constructor accepting message and Throwable
TerracottaNotRunningException(String) - Constructor for exception net.sf.ehcache.terracotta.TerracottaNotRunningException
Constructor accepting message
TerracottaNotRunningException(Throwable) - Constructor for exception net.sf.ehcache.terracotta.TerracottaNotRunningException
Constructor accepting Throwable
TerracottaStore - Interface in net.sf.ehcache.store
Use for internal purpose only.
terracottaStoreInitialized(TerracottaStore) - Method in interface net.sf.ehcache.constructs.nonstop.NonstopActiveDelegateHolder
TerracottaStore got initialized again on rejoin
throwAway(Element, SingleOperationType, RuntimeException) - Method in class net.sf.ehcache.writer.AbstractCacheWriter
This method will be called, whenever an Element couldn't be handled by the writer and all the retryAttempts have been tried.
throwAway(Element, SingleOperationType, RuntimeException) - Method in interface net.sf.ehcache.writer.CacheWriter
This method will be called, whenever an Element couldn't be handled by the writer and all the retryAttempts have been tried.
throwAway(CacheWriter, RuntimeException) - Method in class net.sf.ehcache.writer.writebehind.operations.DeleteOperation
Called when all retries have failed
throwAway(CacheWriter, RuntimeException) - Method in interface net.sf.ehcache.writer.writebehind.operations.SingleOperation
Called when all retries have failed
throwAway(CacheWriter, RuntimeException) - Method in class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Called when all retries have failed
ThrowTimeoutException - Exception in net.sf.ehcache.constructs.nonstop
Exception that can be thrown by Callable's submitted to NonstopExecutorService.
ThrowTimeoutException() - Constructor for exception net.sf.ehcache.constructs.nonstop.ThrowTimeoutException
 
TierableStore - Interface in net.sf.ehcache.store
This is the interface for all tierable stores.
timeBeforeTimeout() - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Get the time until this context will expire
timedOut() - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Check if the context timed out
timeoutBehavior(TimeoutBehaviorConfiguration) - Method in class net.sf.ehcache.config.NonstopConfiguration
Set the value of timeoutBehavior
TimeoutBehaviorConfiguration - Class in net.sf.ehcache.config
Configuration element for configuring timeoutBehavior for nonstop
TimeoutBehaviorConfiguration() - Constructor for class net.sf.ehcache.config.TimeoutBehaviorConfiguration
 
TimeoutBehaviorConfiguration.TimeoutBehaviorType - Enum in net.sf.ehcache.config
Enum encapsulating type of TimeoutBehavior
TimeoutBehaviorConfigurationElement - Class in net.sf.ehcache.config.generator.model.elements
NodeElement representing the TimeoutBehaviorConfiguration
TimeoutBehaviorConfigurationElement(NodeElement, TimeoutBehaviorConfiguration) - Constructor for class net.sf.ehcache.config.generator.model.elements.TimeoutBehaviorConfigurationElement
Constructor accepting the parent and the TimeoutBehaviorConfiguration
timeoutMillis(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder that sets the timeout for CacheLoader execution (0 = no timeout).
timeoutMillis(long) - Method in class net.sf.ehcache.config.NonstopConfiguration
Set the value of timeoutMillis
timeoutMillis - Variable in class net.sf.ehcache.constructs.blocking.BlockingCache
The amount of time to block a thread before a LockTimeoutException is thrown
TimeStampedCounterValue - Class in net.sf.ehcache.util.counter.sampled
A counter value at a particular time instance
TimeStampedCounterValue(long, long) - Constructor for class net.sf.ehcache.util.counter.sampled.TimeStampedCounterValue
Constructor accepting the value of both timestamp and the counter value.
Timestamper - Class in net.sf.ehcache.util
Generates increasing identifiers (in a single VM only).
timeToIdleChanged(long, long) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates a change in the configurations time to idle
timeToIdleChanged(long, long) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates a change in the configurations time to idle
timeToIdleChanged(long, long) - Method in class net.sf.ehcache.store.MemoryStore
Indicates a change in the configurations time to idle
timeToIdleSeconds - Variable in class net.sf.ehcache.config.CacheConfiguration
the time to idle for an element before it expires.
timeToIdleSeconds(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the time to idle for an element before it expires.
timeToLiveChanged(long, long) - Method in interface net.sf.ehcache.config.CacheConfigurationListener
Indicates a change in the configurations time to live
timeToLiveChanged(long, long) - Method in class net.sf.ehcache.management.sampled.SampledCache
Indicates a change in the configurations time to live
timeToLiveChanged(long, long) - Method in class net.sf.ehcache.store.MemoryStore
Indicates a change in the configurations time to live
timeToLiveSeconds - Variable in class net.sf.ehcache.config.CacheConfiguration
Sets the time to idle for an element before it expires.
timeToLiveSeconds(long) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the time to idle for an element before it expires.
TimeUtil - Class in net.sf.ehcache.util
Utilities for converting times
TimeUtil() - Constructor for class net.sf.ehcache.util.TimeUtil
 
toArray() - Method in class net.sf.ehcache.store.CacheKeySet
toArray(T[]) - Method in class net.sf.ehcache.store.CacheKeySet
toArray(T[]) - Method in class net.sf.ehcache.util.CircularLossyQueue
Returns an array of the current elements in the queue.
toArray() - Method in class net.sf.ehcache.util.SetAsList
toArray(T[]) - Method in class net.sf.ehcache.util.SetAsList
toBytes(long) - Method in enum net.sf.ehcache.config.MemoryUnit
returns the amount in bytes
toCompositeData() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
toCompositeData() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
toCompositeData
toCompositeData() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
toCompositeData
toCompositeData() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
toCompositeData
toGigaBytes(long) - Method in enum net.sf.ehcache.config.MemoryUnit
returns the amount in gigabytes
toKiloBytes(long) - Method in enum net.sf.ehcache.config.MemoryUnit
returns the amount in kilobytes
toMap() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated.  
toMap() - Method in class net.sf.ehcache.hibernate.regions.EhcacheDataRegion
toMegaBytes(long) - Method in enum net.sf.ehcache.config.MemoryUnit
returns the amount in megabytes
toMillis(int) - Static method in class net.sf.ehcache.util.TimeUtil
Converts seconds to milliseconds, with a precision of 1 second
toSecs(long) - Static method in class net.sf.ehcache.util.TimeUtil
Converts milliseconds to seconds
toString() - Method in class net.sf.ehcache.Cache
Returns a String representation of Cache.
toString() - Method in class net.sf.ehcache.CacheManager
 
toString() - Method in class net.sf.ehcache.config.CacheConfigError
 
toString() - Method in class net.sf.ehcache.config.ConfigError
 
toString() - Method in class net.sf.ehcache.config.generator.model.AbstractNodeElement
toString() - Method in class net.sf.ehcache.config.generator.model.SimpleNodeAttribute
toString(long) - Method in enum net.sf.ehcache.config.MemoryUnit
Human readable value, with the added unit character as a suffix
toString() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Returns a String representation of Cache.
toString() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Returns a String representation of Cache.
toString() - Method in class net.sf.ehcache.distribution.RMICachePeer
Returns a String that represents the value of this object.
toString() - Method in interface net.sf.ehcache.Ehcache
Returns a String representation of Cache.
toString() - Method in class net.sf.ehcache.Element
Returns a String representation of the Element.
toString() - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Returns a string representation of the object.
toString() - Method in class net.sf.ehcache.event.RegisteredEventListeners
Returns a string representation of the object.
toString() - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. 
toString() - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. 
toString() - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated.  
toString() - Method in class net.sf.ehcache.hibernate.management.impl.CacheRegionStats
 
toString() - Method in class net.sf.ehcache.hibernate.management.impl.CollectionStats
toString
toString() - Method in class net.sf.ehcache.hibernate.management.impl.EntityStats
toString
toString() - Method in class net.sf.ehcache.hibernate.management.impl.QueryStats
toString
toString() - Method in class net.sf.ehcache.search.Attribute
toString() - Method in class net.sf.ehcache.search.impl.BaseResult
 
toString() - Method in class net.sf.ehcache.search.impl.ResultsImpl
 
toString() - Method in class net.sf.ehcache.Statistics
Returns a String representation of the Ehcache statistics.
toString() - Method in class net.sf.ehcache.Status
Returns a string representation of the object.
toString() - Method in class net.sf.ehcache.store.disk.ods.Region
toString() - Method in class net.sf.ehcache.store.disk.Segment
 
toString() - Method in class net.sf.ehcache.store.MemoryStoreEvictionPolicy
 
toString() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
toString() - Method in class net.sf.ehcache.transaction.TransactionIDImpl
toString() - Method in class net.sf.ehcache.transaction.xa.EhcacheXAResourceImpl
 
toString() - Method in class net.sf.ehcache.transaction.xa.SerializableXid
toString() - Method in class net.sf.ehcache.transaction.xa.XATransactionContext
 
toString() - Method in class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
toString() - Method in class net.sf.ehcache.util.counter.sampled.TimeStampedCounterValue
toString() - Method in class net.sf.ehcache.util.ProductInfo
returns long version of the build string
TransactionalEhcacheCollectionRegionAccessStrategy - Class in net.sf.ehcache.hibernate.strategy
JTA CollectionRegionAccessStrategy.
TransactionalEhcacheCollectionRegionAccessStrategy(EhcacheCollectionRegion, Ehcache, Settings) - Constructor for class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheCollectionRegionAccessStrategy
Construct a new collection region access strategy.
TransactionalEhcacheEntityRegionAccessStrategy - Class in net.sf.ehcache.hibernate.strategy
JTA EntityRegionAccessStrategy.
TransactionalEhcacheEntityRegionAccessStrategy(EhcacheEntityRegion, Ehcache, Settings) - Constructor for class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
Construct a new entity region access strategy.
TransactionalExecutorServiceStore - Class in net.sf.ehcache.constructs.nonstop.store
This implementation is identical to TransactionalExecutorServiceStore except that it ensures the transactional context gets propagated to the executor thread.
TransactionalExecutorServiceStore(NonstopActiveDelegateHolder, NonstopConfiguration, NonstopTimeoutBehaviorStoreResolver, CacheCluster, TransactionManagerLookup, ExplicitLockingContextThreadLocal) - Constructor for class net.sf.ehcache.constructs.nonstop.store.TransactionalExecutorServiceStore
Constructor
transactionalMode(String) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the transactionalMode
transactionalMode(CacheConfiguration.TransactionalMode) - Method in class net.sf.ehcache.config.CacheConfiguration
Builder which sets the transactionalMode
TransactionalRMICachePeer - Class in net.sf.ehcache.distribution
An RMI based implementation of CachePeer supporting transactions.
TransactionalRMICachePeer(Ehcache, String, Integer, Integer, Integer) - Constructor for class net.sf.ehcache.distribution.TransactionalRMICachePeer
Construct a new remote peer supporting transactions
TransactionAwareAttributeExtractor - Class in net.sf.ehcache.transaction
Used to extract a search attribute value from an element in a transactional store.
TransactionAwareAttributeExtractor(ReadWriteCopyStrategy<Element>, AttributeExtractor) - Constructor for class net.sf.ehcache.transaction.TransactionAwareAttributeExtractor
Creates an attributed delegating to the supplied extractor, via the given copy strategy.
TransactionController - Class in net.sf.ehcache
TransactionController is used to begin, commit and rollback local transactions
TransactionException - Exception in net.sf.ehcache.transaction
Instances of this class or its subclasses are thrown when an error happen in the transaction subsystem
TransactionException(String) - Constructor for exception net.sf.ehcache.transaction.TransactionException
Create a new TransactionException
TransactionException(String, Throwable) - Constructor for exception net.sf.ehcache.transaction.TransactionException
Create a new TransactionException
TransactionID - Interface in net.sf.ehcache.transaction
A transaction identifier.
TransactionIDFactory - Interface in net.sf.ehcache.transaction
A factory for transaction IDs.
TransactionIDFactoryImpl - Class in net.sf.ehcache.transaction
A TransactionIDFactory implementation with uniqueness across a single JVM
TransactionIDFactoryImpl() - Constructor for class net.sf.ehcache.transaction.TransactionIDFactoryImpl
Create a new TransactionIDFactory
TransactionIDImpl - Class in net.sf.ehcache.transaction
A transaction ID implementation with uniqueness across a single JVM
TransactionIDSerializedForm - Class in net.sf.ehcache.transaction
A replacement serialized form for transaction IDs.
TransactionIDSerializedForm(String, String, long, int, boolean) - Constructor for class net.sf.ehcache.transaction.TransactionIDSerializedForm
Constructor
TransactionInterruptedException - Exception in net.sf.ehcache.transaction
This exception is thrown when a transactional operation got interrupted via Thread.interrupt
TransactionInterruptedException(String) - Constructor for exception net.sf.ehcache.transaction.TransactionInterruptedException
Create a new TransactionInterruptedException
TransactionListener - Interface in net.sf.ehcache.transaction.local
A listener interface to get called back when a transaction is being terminated
transactionManagerLookup(FactoryConfiguration) - Method in class net.sf.ehcache.config.Configuration
Builder to add a transaction manager lookup class to the cache manager, only one of these can be added.
TransactionManagerLookup - Interface in net.sf.ehcache.transaction.manager
Interface to enable a XA transactional cache to access the JTA TransactionManager.
TransactionTimeoutException - Exception in net.sf.ehcache.transaction
This exception is thrown when a transactional operation times out
TransactionTimeoutException(String) - Constructor for exception net.sf.ehcache.transaction.TransactionTimeoutException
Create a new TransactionTimeoutException
tryLock(LockType, long) - Method in class net.sf.ehcache.concurrent.ReadWriteLockSync
Tries to acquire a LockType.READ or WRITE for a certain period
tryLock(LockType, long) - Method in interface net.sf.ehcache.concurrent.Sync
Tries to acquire a LockType.READ or WRITE for a certain period
tryLock(long) - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Attempt to lock the soft lock
tryLock(long) - Method in interface net.sf.ehcache.transaction.SoftLock
Attempt to lock the soft lock
tryReadLockOnKey(Object, long) - Method in class net.sf.ehcache.Cache
Try to get a read lock on a given key.
tryReadLockOnKey(Object, long) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Try to get a read lock on a given key.
tryReadLockOnKey(Object, long) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Try to get a read lock on a given key.
tryReadLockOnKey(Object, long) - Method in interface net.sf.ehcache.Ehcache
Try to get a read lock on a given key.
tryWriteLockOnKey(Object, long) - Method in class net.sf.ehcache.Cache
Try to get a write lock on a given key.
tryWriteLockOnKey(Object, long) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Try to get a write lock on a given key.
tryWriteLockOnKey(Object, long) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Try to get a write lock on a given key.
tryWriteLockOnKey(Object, long) - Method in interface net.sf.ehcache.Ehcache
Try to get a write lock on a given key.
type(String) - Method in class net.sf.ehcache.config.TimeoutBehaviorConfiguration
Set the type of timeout behavior
typeFor(String, Object) - Static method in enum net.sf.ehcache.search.attribute.AttributeType
Get the appropriate @{link AttributeType enum for the given object value.

U

unbind(RMICachePeer) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerListener
Unbinds an RMICachePeer and unexports it.
unbind() - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Unbinds a store instance from this factory
UnboundedPool - Class in net.sf.ehcache.pool.impl
A no-op pool which does not enforce any resource consumption limit.
UnboundedPool() - Constructor for class net.sf.ehcache.pool.impl.UnboundedPool
Create an UnboundedPool instance
underlyingCache - Variable in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
The decorated Ehcache, has protected visibility so that sub-classes can have access to it.
underlyingStore - Variable in class net.sf.ehcache.transaction.AbstractTransactionStore
The underlying store wrapped by this store
underlyingTerracottaStore() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Get the underlying Terracotta store
unfreeze() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Unfreeze the soft lock
unfreeze() - Method in interface net.sf.ehcache.transaction.SoftLock
Unfreeze the soft lock
unlink() - Method in class net.sf.ehcache.pool.impl.AbstractPoolAccessor
unlink this PoolAccessor from its pool.
unlink() - Method in interface net.sf.ehcache.pool.PoolAccessor
unlink this PoolAccessor from its pool.
unlock(LockType) - Method in class net.sf.ehcache.concurrent.ReadWriteLockSync
Releases the lock held by the current Thread.
unlock(LockType) - Method in interface net.sf.ehcache.concurrent.Sync
Releases the lock held by the current Thread.
unlock(Object) - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. 
unlock() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Unlock the soft lock.
unlock() - Method in interface net.sf.ehcache.transaction.SoftLock
Unlock the soft lock.
unlockedGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Gets the value associated with the key without acquiring any locks.
unlockedGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Gets the value associated with the key without acquiring any locks.
unlockedGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Gets the value associated with the key without acquiring any locks.
unlockedGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Gets the value associated with the key without acquiring any locks.
unlockedGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Gets the value associated with the key without acquiring any locks.
unlockedGet(Object) - Method in interface net.sf.ehcache.store.TerracottaStore
Gets the value associated with the key without acquiring any locks.
unlockedGet(Object) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Gets the value associated with the key without acquiring any locks.
unlockedGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Same as TerracottaStore.unlockedGet(Object) but does not update statistics
unlockedGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Same as TerracottaStore.unlockedGet(Object) but does not update statistics
unlockedGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Same as TerracottaStore.unlockedGet(Object) but does not update statistics
unlockedGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Same as TerracottaStore.unlockedGet(Object) but does not update statistics
unlockedGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Same as TerracottaStore.unlockedGet(Object) but does not update statistics
unlockedGetQuiet(Object) - Method in interface net.sf.ehcache.store.TerracottaStore
Same as TerracottaStore.unlockedGet(Object) but does not update statistics
unlockedGetQuiet(Object) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Same as TerracottaStore.unlockedGet(Object) but does not update statistics
UnlockedRateStatistic - Class in net.sf.ehcache.util.ratestatistics
A lightweight non-thread-safe rate statistic implementation.
UnlockedRateStatistic(long, TimeUnit) - Constructor for class net.sf.ehcache.util.ratestatistics.UnlockedRateStatistic
Create an UnlockedRateStatistic instance with the given average period.
unlockItem(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
unlockItem(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
unlockItem(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheCollectionRegionAccessStrategy
Since this is a non-strict read/write strategy item locking is not used.
unlockItem(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
Since this is a non-strict read/write strategy item locking is not used.
unlockItem(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheCollectionRegionAccessStrategy
A no-op since this cache is read-only
unlockItem(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
A no-op since this cache is read-only
unlockItem(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheCollectionRegionAccessStrategy
unlockItem(Object, SoftLock) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
unlockRegion(SoftLock) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareCollectionRegionAccessStrategy
unlockRegion(SoftLock) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
unpinAll() - Method in class net.sf.ehcache.Cache
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
unpin all pinned keys
unpinAll() - Method in interface net.sf.ehcache.Ehcache
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
unpinAll() - Method in class net.sf.ehcache.store.disk.DiskStore
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.store.FrontEndCacheTier
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.store.LegacyStoreWrapper
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.store.LruMemoryStore.SpoolingLinkedHashMap
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.store.LruMemoryStore
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.store.MemoryStore
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.store.NullStore
unpin all pinned keys
unpinAll() - Method in interface net.sf.ehcache.store.Store
unpin all pinned keys
unpinAll() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
unpin all pinned keys
unregister(EhcacheXAResource) - Method in class net.sf.ehcache.transaction.manager.DefaultTransactionManagerLookup
execute txnManager specific code to unregister the XAResource for recovery.
unregister(EhcacheXAResource) - Method in interface net.sf.ehcache.transaction.manager.TransactionManagerLookup
execute txnManager specific code to unregister the XAResource for recovery.
unregisterCacheExtension(CacheExtension) - Method in class net.sf.ehcache.Cache
Unregister a CacheExtension with the cache.
unregisterCacheExtension(CacheExtension) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Unregister a CacheExtension with the cache.
unregisterCacheExtension(CacheExtension) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Unregister a CacheExtension with the cache.
unregisterCacheExtension(CacheExtension) - Method in interface net.sf.ehcache.Ehcache
Unregister a CacheExtension with the cache.
unregisterCacheLoader(CacheLoader) - Method in class net.sf.ehcache.Cache
Unregister a CacheLoader with the cache.
unregisterCacheLoader(CacheLoader) - Method in class net.sf.ehcache.constructs.blocking.BlockingCache
Unregister a CacheLoader with the cache.
unregisterCacheLoader(CacheLoader) - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Unregister a CacheLoader with the cache.
unregisterCacheLoader(CacheLoader) - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Unregister a CacheLoader with the cache.
unregisterCacheLoader(CacheLoader) - Method in interface net.sf.ehcache.Ehcache
Unregister a CacheLoader with the cache.
unregisterCacheWriter() - Method in class net.sf.ehcache.Cache
Unregister the CacheWriter from the cache.
unregisterCacheWriter() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
Unregister the CacheWriter from the cache.
unregisterCacheWriter() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Unregister the CacheWriter from the cache.
unregisterCacheWriter() - Method in interface net.sf.ehcache.Ehcache
Unregister the CacheWriter from the cache.
unregisterListener(CacheManagerEventListener) - Method in class net.sf.ehcache.event.CacheManagerEventListenerRegistry
Removes a listener from the notification service.
unregisterListener(CacheEventListener) - Method in class net.sf.ehcache.event.RegisteredEventListeners
Removes a listener from the notification service.
unregisterMBean() - Method in class net.sf.ehcache.hibernate.management.impl.ProviderMBeanRegistrationHelper
Unregisters previously registered mbean.
unregisterPeer(String) - Method in interface net.sf.ehcache.distribution.CacheManagerPeerProvider
Unregisters a peer.
unregisterPeer(String) - Method in class net.sf.ehcache.distribution.RMICacheManagerPeerProvider
Unregisters a peer
unretrievedGet(Object) - Method in class net.sf.ehcache.store.disk.DiskStore
Return the unretrieved (undecoded) value for this key
unsafeGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Returns the local value associated with the key.
unsafeGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Returns the local value associated with the key.
unsafeGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Returns the local value associated with the key.
unsafeGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Returns the local value associated with the key.
unsafeGet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Returns the local value associated with the key.
unsafeGet(Object) - Method in interface net.sf.ehcache.store.TerracottaStore
Returns the local value associated with the key.
unsafeGet(Object) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Returns the local value associated with the key.
unsafeGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
Same as TerracottaStore.unsafeGet(Object) but does not update last usage statistics
unsafeGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
Same as TerracottaStore.unsafeGet(Object) but does not update last usage statistics
unsafeGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
Same as TerracottaStore.unsafeGet(Object) but does not update last usage statistics
unsafeGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
Same as TerracottaStore.unsafeGet(Object) but does not update last usage statistics
unsafeGetQuiet(Object) - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
Same as TerracottaStore.unsafeGet(Object) but does not update last usage statistics
unsafeGetQuiet(Object) - Method in interface net.sf.ehcache.store.TerracottaStore
Same as TerracottaStore.unsafeGet(Object) but does not update last usage statistics
unsafeGetQuiet(Object) - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
Same as TerracottaStore.unsafeGet(Object) but does not update last usage statistics
UnsafeSizeOf - Class in net.sf.ehcache.pool.sizeof
Unsafe.theUnsafe based sizeOf measurement All constructors will throw UnsupportedOperationException if theUnsafe isn't accessible on this platform
UnsafeSizeOf() - Constructor for class net.sf.ehcache.pool.sizeof.UnsafeSizeOf
Builds a new SizeOf that will not filter fields and will cache reflected fields
UnsafeSizeOf(SizeOfFilter) - Constructor for class net.sf.ehcache.pool.sizeof.UnsafeSizeOf
Builds a new SizeOf that will filter fields according to the provided filter and will cache reflected fields
UnsafeSizeOf(SizeOfFilter, boolean) - Constructor for class net.sf.ehcache.pool.sizeof.UnsafeSizeOf
Builds a new SizeOf that will filter fields according to the provided filter
update(Object) - Method in class net.sf.ehcache.constructs.blocking.UpdatingSelfPopulatingCache
Element can never be null.
update(Object, Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheNonstrictReadWriteCache
Deprecated. Removes the invalidated item.
update(Object, Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadOnlyCache
Deprecated. Throws UnsupportedOperationException since items in a read-only cache should not be mutated.
update(Object, Object, Object, Object) - Method in class net.sf.ehcache.hibernate.ccs.EhcacheReadWriteCache
Deprecated. A No-Op, since we are an asynchronous cache concurrency strategy.
update(Object, Object) - Method in class net.sf.ehcache.hibernate.EhCache
Deprecated. Updates an object in the cache, or if it does not exist, inserts it.
update(Object, Object, Object, Object) - Method in class net.sf.ehcache.hibernate.nonstop.NonstopAwareEntityRegionAccessStrategy
update(Object, Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.NonStrictReadWriteEhcacheEntityRegionAccessStrategy
Removes the entry since this is a non-strict read/write cache strategy.
update(Object, Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.ReadOnlyEhcacheEntityRegionAccessStrategy
Throws UnsupportedOperationException since this cache is read-only
update(Object, Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.ReadWriteEhcacheEntityRegionAccessStrategy
A no-op since this is an asynchronous cache access strategy.
update(Object, Object, Object, Object) - Method in class net.sf.ehcache.hibernate.strategy.TransactionalEhcacheEntityRegionAccessStrategy
updateAccessStatistics() - Method in class net.sf.ehcache.Element
Sets the last access time to now and increase the hit count.
updateCheck(boolean) - Method in class net.sf.ehcache.config.Configuration
Builder to set the state of the automated update check.
UpdateChecker - Class in net.sf.ehcache.util
Check for new Ehcache updates and alert users if an update is available
UpdateChecker() - Constructor for class net.sf.ehcache.util.UpdateChecker
 
updateCount - Variable in class net.sf.ehcache.hibernate.management.impl.CollectionStats
updateCount
updateCount - Variable in class net.sf.ehcache.hibernate.management.impl.EntityStats
updateCount
updateElement(Element) - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Change the Element at the key this soft lock is guarding
updateElement(Element) - Method in interface net.sf.ehcache.transaction.SoftLock
Change the Element at the key this soft lock is guarding
updateEntryValue(Object, Object) - Method in interface net.sf.ehcache.constructs.blocking.UpdatingCacheEntryFactory
Perform an incremental update of data within a CacheEntry.
updateLastAccessTime(long, Element) - Method in class net.sf.ehcache.DefaultElementEvictionData
Updates the last access time.
updateLastAccessTime(long, Element) - Method in interface net.sf.ehcache.ElementEvictionData
Updates the last access time.
updateSoftLock(String, SoftLock) - Method in class net.sf.ehcache.transaction.local.LocalTransactionContext
Update a soft lock already registered in the context
updateUpdateStatistics() - Method in class net.sf.ehcache.Element
Sets the last access time to now without updating the hit count.
UpdatingCacheEntryFactory - Interface in net.sf.ehcache.constructs.blocking
A CacheEntryFactory with one additional method, updateEntryValue((Serializable key, Serializable value) which allows the cache entry to updated rather than replaced.
UpdatingSelfPopulatingCache - Class in net.sf.ehcache.constructs.blocking
A Cache backed cache that creates entries on demand.
UpdatingSelfPopulatingCache(Ehcache, UpdatingCacheEntryFactory) - Constructor for class net.sf.ehcache.constructs.blocking.UpdatingSelfPopulatingCache
Creates a SelfPopulatingCache.
url(String) - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Builder method to set the URL.
url(String, String) - Method in class net.sf.ehcache.config.TerracottaClientConfiguration
Builder method to set the URL for a host and a port.
USER_FILTER_RESOURCE - Static variable in class net.sf.ehcache.pool.impl.DefaultSizeOfEngine
System property defining a user specific resource based size-of filter.
usesCacheDefaultLifespan() - Method in class net.sf.ehcache.Element
 

V

validate(Configuration) - Method in class net.sf.ehcache.config.CacheConfiguration
Validates the configuration
validate() - Method in class net.sf.ehcache.config.Configuration
Validates the current configuration
validateCompleteConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Used to validate what should be a complete Cache Configuration.
validateConfiguration() - Method in class net.sf.ehcache.config.CacheConfiguration
Used to validate a Cache Configuration.
validateValue(String, Object) - Method in enum net.sf.ehcache.search.attribute.AttributeType
Validate that the given value is in fact of the correct type
VALUE - Static variable in interface net.sf.ehcache.search.Query
The search attribute for a cache element's value.
valueMode(String) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
valueMode(TerracottaConfiguration.ValueMode) - Method in class net.sf.ehcache.config.TerracottaConfiguration
 
ValueObjectAttributeExtractor - Class in net.sf.ehcache.search.attribute
Attempt to use the element value object itself as a search attribute.
ValueObjectAttributeExtractor() - Constructor for class net.sf.ehcache.search.attribute.ValueObjectAttributeExtractor
 
valueOf(String) - Static method in enum net.sf.ehcache.cluster.ClusterScheme
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.concurrent.LockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.CacheConfiguration.TransactionalMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.CacheWriterConfiguration.WriteMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.Configuration.Monitoring
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.generator.model.XMLGeneratorVisitor.OutputBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.MemoryUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.PinningConfiguration.Store
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.SizeOfPolicyConfiguration.MaxDepthExceededBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.TerracottaConfiguration.Consistency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.TerracottaConfiguration.StorageStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.TerracottaConfiguration.ValueMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.config.TimeoutBehaviorConfiguration.TimeoutBehaviorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.distribution.RmiEventMessage.RmiEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.event.NotificationScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.search.attribute.AttributeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.search.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.store.MemoryStoreEvictionPolicy.MemoryStoreEvictionPolicyEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.transaction.xa.processor.XARequest.RequestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.sf.ehcache.writer.writebehind.operations.SingleOperationType
Returns the enum constant of this type with the specified name.
values() - Static method in enum net.sf.ehcache.cluster.ClusterScheme
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.concurrent.LockType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.CacheConfiguration.TransactionalMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.CacheWriterConfiguration.WriteMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.Configuration.Monitoring
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.generator.model.XMLGeneratorVisitor.OutputBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.MemoryUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.PinningConfiguration.Store
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class net.sf.ehcache.config.Searchable
Are values searchable?
values(boolean) - Method in class net.sf.ehcache.config.Searchable
Toggle searchable values
values() - Static method in enum net.sf.ehcache.config.SizeOfPolicyConfiguration.MaxDepthExceededBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.TerracottaConfiguration.Consistency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.TerracottaConfiguration.StorageStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.TerracottaConfiguration.ValueMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.config.TimeoutBehaviorConfiguration.TimeoutBehaviorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.distribution.RmiEventMessage.RmiEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.event.NotificationScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.pool.sizeof.JvmInformation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.search.attribute.AttributeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.search.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class net.sf.ehcache.search.expression.InCollection
Return values.
values() - Method in class net.sf.ehcache.store.chm.SelectableConcurrentHashMap
 
values() - Static method in enum net.sf.ehcache.store.MemoryStoreEvictionPolicy.MemoryStoreEvictionPolicyEnum
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.transaction.xa.processor.XARequest.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.sf.ehcache.writer.writebehind.operations.SingleOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES_DEFAULT - Static variable in class net.sf.ehcache.config.Searchable
Default for auto-searchable values
VicariousThreadLocal<T> - Class in net.sf.ehcache.util.lang
A drop-in replacement ThreadLocal implementation that does not leak when thread-local values reference the ThreadLocal object.
VicariousThreadLocal() - Constructor for class net.sf.ehcache.util.lang.VicariousThreadLocal
Creates a new VicariousThreadLocal.
visit(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Visit the element
visit(NodeElement) - Method in interface net.sf.ehcache.config.generator.model.NodeElementVisitor
Visit the element
visitAttribute(NodeElement, NodeAttribute) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Visits an attribute.
visitAttributes(NodeElement, List<NodeAttribute>) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Visits the attributes of the element.
visitAttributes(NodeElement, List<NodeAttribute>) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Visits the attributes of the element.
visitElement(NodeElement) - Method in class net.sf.ehcache.config.generator.model.AbstractDepthFirstVisitor
Visits the element.
visitElement(NodeElement) - Method in class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Visits the element.
VmUtils - Class in net.sf.ehcache.util
Misc.
VmUtils() - Constructor for class net.sf.ehcache.util.VmUtils
 

W

waitUntilClusterBulkLoadComplete() - Method in class net.sf.ehcache.Cache
This method waits until all the connected nodes have disabled bulk-load.
waitUntilClusterBulkLoadComplete() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
This method waits until all the connected nodes have disabled bulk-load.
waitUntilClusterBulkLoadComplete() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
This method waits until all the connected nodes have disabled bulk-load.
waitUntilClusterBulkLoadComplete() - Method in interface net.sf.ehcache.Ehcache
This method waits until all the connected nodes have disabled bulk-load.
waitUntilClusterCoherent() - Method in class net.sf.ehcache.Cache
Deprecated. use Cache.waitUntilClusterBulkLoadComplete() instead
waitUntilClusterCoherent() - Method in class net.sf.ehcache.constructs.classloader.ClassLoaderAwareCache
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilClusterCoherent() - Method in class net.sf.ehcache.constructs.EhcacheDecoratorAdapter
Deprecated. Use EhcacheDecoratorAdapter.waitUntilClusterBulkLoadComplete() instead
waitUntilClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.ExceptionOnTimeoutStore
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.ExecutorServiceStore
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.LocalReadsOnTimeoutStore
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.NonstopStoreImpl
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilClusterCoherent() - Method in class net.sf.ehcache.constructs.nonstop.store.NoOpOnTimeoutStore
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilClusterCoherent() - Method in interface net.sf.ehcache.Ehcache
Deprecated. Use Ehcache.waitUntilClusterBulkLoadComplete() instead
waitUntilClusterCoherent() - Method in class net.sf.ehcache.store.AbstractStore
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilClusterCoherent() - Method in interface net.sf.ehcache.store.Store
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilClusterCoherent() - Method in class net.sf.ehcache.transaction.AbstractTransactionStore
This method waits until the cache is in coherent mode in all the connected nodes.
waitUntilNodeJoinsCluster() - Method in interface net.sf.ehcache.cluster.CacheCluster
Waits until the current node has successfully joined the cluster.
waitUntilNodeJoinsCluster() - Method in class net.sf.ehcache.cluster.NoopCacheCluster
Waits until the current node has successfully joined the cluster.
waitUntilNodeJoinsCluster() - Method in class net.sf.ehcache.terracotta.TerracottaCacheCluster
Waits until the current node has successfully joined the cluster.
waitUntilRejoinComplete() - Method in class net.sf.ehcache.terracotta.TerracottaClient
Block thread until rejoin is complete
wasPinned() - Method in class net.sf.ehcache.transaction.ReadCommittedSoftLockImpl
Check if the key was pinned in the underlying store before its element was replaced by this soft lock
wasPinned() - Method in interface net.sf.ehcache.transaction.SoftLock
Check if the key was pinned in the underlying store before its element was replaced by this soft lock
WeakIdentityConcurrentMap<K,V> - Class in net.sf.ehcache.util
A poor man's implementation of a WeakIdentityConcurrentMap to hold the CacheManager associated ExecutorServices
WeakIdentityConcurrentMap() - Constructor for class net.sf.ehcache.util.WeakIdentityConcurrentMap
Constructor
WeakIdentityConcurrentMap(WeakIdentityConcurrentMap.CleanUpTask<V>) - Constructor for class net.sf.ehcache.util.WeakIdentityConcurrentMap
Constructor
WeakIdentityConcurrentMap.CleanUpTask<T> - Interface in net.sf.ehcache.util
 
write(Element) - Method in class net.sf.ehcache.store.disk.DiskStorageFactory
Write the given element to disk, and return the associated marker.
write(Element) - Method in class net.sf.ehcache.writer.AbstractCacheWriter
Write the specified value under the specified key to the underlying store.
write(Element) - Method in interface net.sf.ehcache.writer.CacheWriter
Write the specified value under the specified key to the underlying store.
write(Element) - Method in interface net.sf.ehcache.writer.writebehind.WriteBehind
Add a write operation for a given element.
write(Element) - Method in class net.sf.ehcache.writer.writebehind.WriteBehindQueueManager
Add a write operation for a given element.
writeAll(Collection<Element>) - Method in class net.sf.ehcache.writer.AbstractCacheWriter
Write the specified Elements to the underlying store.
writeAll(Collection<Element>) - Method in interface net.sf.ehcache.writer.CacheWriter
Write the specified Elements to the underlying store.
WriteAllOperation - Class in net.sf.ehcache.writer.writebehind.operations
Implements the write all operation for write behind
WriteAllOperation(List<Element>) - Constructor for class net.sf.ehcache.writer.writebehind.operations.WriteAllOperation
Create a new write all operation for the provided list of element
writeBatching(boolean) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
writeBatchSize(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
WriteBehind - Interface in net.sf.ehcache.writer.writebehind
An interface for write behind behavior.
writeBehindConcurrency(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
WriteBehindManager - Class in net.sf.ehcache.writer.writebehind
Implements a WriterManager that writes elements to a queue first and in the background sends the to the CacheWriter.
WriteBehindManager() - Constructor for class net.sf.ehcache.writer.writebehind.WriteBehindManager
 
writeBehindMaxQueueSize(int) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
WriteBehindQueueManager - Class in net.sf.ehcache.writer.writebehind
 
WriteBehindQueueManager(CacheConfiguration) - Constructor for class net.sf.ehcache.writer.writebehind.WriteBehindQueueManager
Create a new write behind queue manager.
writeCoalescing(boolean) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
writeLock(Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Attempts to write lock the mapping for the given key.
writeMode(String) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
writeMode(CacheWriterConfiguration.WriteMode) - Method in class net.sf.ehcache.config.CacheWriterConfiguration
 
WriteOperation - Class in net.sf.ehcache.writer.writebehind.operations
Implements the write operation for write behind
WriteOperation(Element) - Constructor for class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Create a new write operation for a particular element
WriteOperation(Element, long) - Constructor for class net.sf.ehcache.writer.writebehind.operations.WriteOperation
Create a new write operation for a particular element and creation time
WriteThroughManager - Class in net.sf.ehcache.writer.writethrough
Implements a WriterManager that writes elements directly through to the underlying store.
WriteThroughManager() - Constructor for class net.sf.ehcache.writer.writethrough.WriteThroughManager
 
writeUnlock(Object) - Method in class net.sf.ehcache.hibernate.regions.EhcacheTransactionalDataRegion
Attempts to write unlock the mapping for the given key.

X

xaCommit() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called when the Cache's XAResource has been asked to commit
xaCommit() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called when the Cache's XAResource has been asked to commit
xaCommit() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called when the Cache's XAResource has been asked to commit
xaCommit() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called when the Cache's XAResource has been asked to commit
XAExecutionListener - Interface in net.sf.ehcache.transaction.xa
Listener interface which provides callback hooks for listening to the 2PC lifecycle
XARequest - Class in net.sf.ehcache.transaction.xa.processor
 
XARequest(XARequest.RequestType, Xid) - Constructor for class net.sf.ehcache.transaction.xa.processor.XARequest
Constructor
XARequest(XARequest.RequestType, Xid, boolean) - Constructor for class net.sf.ehcache.transaction.xa.processor.XARequest
Constructor
XARequest.RequestType - Enum in net.sf.ehcache.transaction.xa.processor
XA Requests types
XARequestProcessor - Class in net.sf.ehcache.transaction.xa.processor
Default implementation for XARequestProcessor.
XARequestProcessor(EhcacheXAResourceImpl) - Constructor for class net.sf.ehcache.transaction.xa.processor.XARequestProcessor
Constructor
xaRollback() - Method in interface net.sf.ehcache.statistics.LiveCacheStatisticsData
Called when the Cache's XAResource has been asked to rollback
xaRollback() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsImpl
Called when the Cache's XAResource has been asked to rollback
xaRollback() - Method in class net.sf.ehcache.statistics.LiveCacheStatisticsWrapper
Called when the Cache's XAResource has been asked to rollback
xaRollback() - Method in class net.sf.ehcache.statistics.NullLiveCacheStatisticsData
Called when the Cache's XAResource has been asked to rollback
XAThreadPool - Class in net.sf.ehcache.transaction.xa.processor
Fast and minimalistic thread pool from which threads can be reserved and used many times until they are manually released.
XAThreadPool() - Constructor for class net.sf.ehcache.transaction.xa.processor.XAThreadPool
 
XAThreadPool.MultiRunner - Class in net.sf.ehcache.transaction.xa.processor
Pooled thread wrapper which allows reuse of the same thread
XATransactionContext - Class in net.sf.ehcache.transaction.xa
An XATransactionContext represents the data local to a Transaction that involves a transactional Cache.
XATransactionContext(Store) - Constructor for class net.sf.ehcache.transaction.xa.XATransactionContext
Constructor
XATransactionStore - Class in net.sf.ehcache.transaction.xa
 
XATransactionStore(TransactionManagerLookup, SoftLockFactory, TransactionIDFactory, Ehcache, Store, ReadWriteCopyStrategy<Element>) - Constructor for class net.sf.ehcache.transaction.xa.XATransactionStore
Constructor
XidTransactionID - Interface in net.sf.ehcache.transaction.xa
A special TransactionID using a XID internally
XidTransactionIDImpl - Class in net.sf.ehcache.transaction.xa
 
XidTransactionIDImpl(Xid) - Constructor for class net.sf.ehcache.transaction.xa.XidTransactionIDImpl
Constructor
XidTransactionIDSerializedForm - Class in net.sf.ehcache.transaction
A replacement serialized form for XID transaction IDs.
XidTransactionIDSerializedForm(String, Xid, String) - Constructor for class net.sf.ehcache.transaction.XidTransactionIDSerializedForm
Constructor
XMLGeneratorVisitor - Class in net.sf.ehcache.config.generator.model
Implementation of an ElementVisitor extending from AbstractDepthFirstVisitor which can generate XML out of a NodeElement.
XMLGeneratorVisitor(PrintWriter) - Constructor for class net.sf.ehcache.config.generator.model.XMLGeneratorVisitor
Constructor accepting the PrintWriter.
XMLGeneratorVisitor.OutputBehavior - Enum in net.sf.ehcache.config.generator.model
Enum controlling the generated XML output

A B C D E F G H I J K L M N O P Q R S T U V W X
ehcache

Copyright © 2003-2012 Terracotta, Inc.. All Rights Reserved.