ehcache

Serialized Form


Package net.sf.ehcache

Class net.sf.ehcache.CacheException extends RuntimeException implements Serializable

serialVersionUID: 142468800110101833L

Class net.sf.ehcache.Element extends Object implements Serializable

serialVersionUID: 1098572221246444544L

Serialization Methods

readObject

private void readObject(ObjectInputStream in)
                 throws IOException,
                        ClassNotFoundException
Custom serialization read logic

Throws:
IOException
ClassNotFoundException

writeObject

private void writeObject(ObjectOutputStream out)
                  throws IOException
Custom serialization write logic

Throws:
IOException
Serialized Fields

key

Object key
the cache key.


value

Object value
the value.


version

long version
version of the element. System.currentTimeMillis() is used to compute version for updated elements. That way, the actual version of the updated element does not need to be checked.


hitCount

long hitCount
The number of times the element was hit.


timeToLive

int timeToLive
The amount of time for the element to live, in seconds. 0 indicates unlimited.


timeToIdle

int timeToIdle
The amount of time for the element to idle, in seconds. 0 indicates unlimited.


lastUpdateTime

long lastUpdateTime
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. The creation time will be the creation time of the new Element, not the original one, so that TTL concepts still work.


cacheDefaultLifespan

boolean cacheDefaultLifespan

id

long id

Class net.sf.ehcache.ElementData extends Object implements Serializable

Serialization Methods

readExternal

public void readExternal(ObjectInput arg0)
                  throws IOException,
                         ClassNotFoundException
Throws:
IOException
ClassNotFoundException

writeExternal

public void writeExternal(ObjectOutput arg0)
                   throws IOException
Throws:
IOException

Class net.sf.ehcache.EternalElementData extends ElementData implements Serializable

Serialization Methods

readExternal

public void readExternal(ObjectInput arg0)
                  throws IOException,
                         ClassNotFoundException
Throws:
IOException
ClassNotFoundException

writeExternal

public void writeExternal(ObjectOutput arg0)
                   throws IOException
Throws:
IOException

Class net.sf.ehcache.LoaderTimeoutException extends CacheException implements Serializable

Class net.sf.ehcache.MimeTypeByteArray extends Object implements Serializable

Serialized Fields

mimeType

String mimeType

value

byte[] value

Class net.sf.ehcache.NonEternalElementData extends ElementData implements Serializable

Serialization Methods

readExternal

public void readExternal(ObjectInput arg0)
                  throws IOException,
                         ClassNotFoundException
Throws:
IOException
ClassNotFoundException

writeExternal

public void writeExternal(ObjectOutput arg0)
                   throws IOException
Throws:
IOException

Class net.sf.ehcache.ObjectExistsException extends CacheException implements Serializable

Class net.sf.ehcache.Status extends Object implements Serializable

serialVersionUID: 2732730630423367732L

Serialized Fields

name

String name

intValue

int intValue

Package net.sf.ehcache.cluster

Class net.sf.ehcache.cluster.ClusterSchemeNotAvailableException extends CacheException implements Serializable

Serialized Fields

unavailableClusterScheme

ClusterScheme unavailableClusterScheme

Package net.sf.ehcache.config

Class net.sf.ehcache.config.InvalidConfigurationException extends CacheException implements Serializable


Package net.sf.ehcache.constructs.blocking

Class net.sf.ehcache.constructs.blocking.LockTimeoutException extends CacheException implements Serializable


Package net.sf.ehcache.constructs.nonstop

Class net.sf.ehcache.constructs.nonstop.NonStopCacheException extends CacheException implements Serializable

Class net.sf.ehcache.constructs.nonstop.RejoinCacheException extends CacheException implements Serializable


Package net.sf.ehcache.constructs.nonstop.concurrency

Class net.sf.ehcache.constructs.nonstop.concurrency.InvalidLockStateAfterRejoinException extends NonStopCacheException implements Serializable

Class net.sf.ehcache.constructs.nonstop.concurrency.LockOperationTimedOutNonstopException extends NonStopCacheException implements Serializable


Package net.sf.ehcache.distribution

Class net.sf.ehcache.distribution.ConfigurableRMIClientSocketFactory extends Object implements Serializable

serialVersionUID: 4920508630517373246L

Serialized Fields

socketTimeoutMillis

int socketTimeoutMillis

Class net.sf.ehcache.distribution.EventMessage extends Object implements Serializable

serialVersionUID: -293616939110963630L

Serialized Fields

key

Serializable key
The key component.

Class net.sf.ehcache.distribution.LegacyEventMessage extends EventMessage implements Serializable

serialVersionUID: -293616939110963630L

Serialization Methods

readObject

private void readObject(ObjectInputStream in)
                 throws IOException,
                        ClassNotFoundException
Throws:
IOException
ClassNotFoundException

writeObject

private void writeObject(ObjectOutputStream out)
                  throws IOException
Throws:
IOException
Serialized Fields

event

int event
The event component.


wasElementNotNull

boolean wasElementNotNull
Used to check if the value has been GCed

Class net.sf.ehcache.distribution.RemoteCacheException extends CacheException implements Serializable

Class net.sf.ehcache.distribution.RMICachePeer extends UnicastRemoteObject implements Serializable

Serialized Fields

hostname

String hostname

rmiRegistryPort

Integer rmiRegistryPort

remoteObjectPort

Integer remoteObjectPort

cache

Ehcache cache

Class net.sf.ehcache.distribution.RMICachePeer_Stub extends RemoteStub implements Serializable

serialVersionUID: 2L

Class net.sf.ehcache.distribution.RmiEventMessage extends EventMessage implements Serializable

Serialized Fields

type

RmiEventMessage.RmiEventType type
The event component.


element

Element element
The element component.

Class net.sf.ehcache.distribution.TransactionalRMICachePeer extends RMICachePeer implements Serializable

Serialized Fields

cache

Ehcache cache

Package net.sf.ehcache.hibernate.management.impl

Class net.sf.ehcache.hibernate.management.impl.AggregateCacheRegionStats extends CacheRegionStats implements Serializable

Serialized Fields

nodeCount

int nodeCount

Class net.sf.ehcache.hibernate.management.impl.CacheRegionStats extends Object implements Serializable

Serialized Fields

region

String region
region name


shortName

String shortName
region short name


hitCount

long hitCount
hit count


missCount

long missCount
miss count


putCount

long putCount
put count


hitRatio

double hitRatio
hit ratio


elementCountInMemory

long elementCountInMemory
in-memory element count


elementCountOnDisk

long elementCountOnDisk
on-disk element count


elementCountTotal

long elementCountTotal
total element count

Class net.sf.ehcache.hibernate.management.impl.CollectionStats extends Object implements Serializable

Serialized Fields

roleName

String roleName
roleName


shortName

String shortName
shortName


loadCount

long loadCount
loadCount


fetchCount

long fetchCount
fetchCount


updateCount

long updateCount
updateCount


removeCount

long removeCount
removeCount


recreateCount

long recreateCount
recreateCount

Class net.sf.ehcache.hibernate.management.impl.EntityStats extends Object implements Serializable

Serialized Fields

name

String name
name


shortName

String shortName
shortName


loadCount

long loadCount
loadCount


updateCount

long updateCount
updateCount


insertCount

long insertCount
insertCount


deleteCount

long deleteCount
deleteCount


fetchCount

long fetchCount
fetchCount


optimisticFailureCount

long optimisticFailureCount
optimisticFailureCount

Class net.sf.ehcache.hibernate.management.impl.QueryStats extends Object implements Serializable

Serialized Fields

query

String query
query


cacheHitCount

long cacheHitCount
cacheHitCount


cacheMissCount

long cacheMissCount
cacheMissCount


cachePutCount

long cachePutCount
cachePutCount


executionCount

long executionCount
executionCount


executionRowCount

long executionRowCount
executionRowCount


executionAvgTime

long executionAvgTime
executionAvgTime


executionMaxTime

long executionMaxTime
executionMaxTime


executionMinTime

long executionMinTime
executionMinTime


Package net.sf.ehcache.hibernate.strategy

Class net.sf.ehcache.hibernate.strategy.AbstractReadWriteEhcacheAccessStrategy.Item extends Object implements Serializable

serialVersionUID: 1L

Serialized Fields

value

Object value

version

Object version

timestamp

long timestamp

Class net.sf.ehcache.hibernate.strategy.AbstractReadWriteEhcacheAccessStrategy.Lock extends Object implements Serializable

serialVersionUID: 2L

Serialized Fields

sourceUuid

UUID sourceUuid

lockId

long lockId

version

Object version

timeout

long timeout

concurrent

boolean concurrent

multiplicity

int multiplicity

unlockTimestamp

long unlockTimestamp

Package net.sf.ehcache.management

Class net.sf.ehcache.management.Cache extends Object implements Serializable

serialVersionUID: 3477287016924524437L

Serialized Fields

objectName

ObjectName objectName

Class net.sf.ehcache.management.CacheConfiguration extends Object implements Serializable

serialVersionUID: -8944774509593267228L

Serialized Fields

objectName

ObjectName objectName

Class net.sf.ehcache.management.CacheStatistics extends Object implements Serializable

serialVersionUID: 8085302752781762030L

Serialized Fields

statistics

StatisticsGateway statistics

objectName

ObjectName objectName

Class net.sf.ehcache.management.Store extends Object implements Serializable

serialVersionUID: 3477287016924524437L

Serialized Fields

objectName

ObjectName objectName

storeBean

DynamicMBean storeBean

Package net.sf.ehcache.management.provider

Class net.sf.ehcache.management.provider.MBeanRegistrationProviderException extends Exception implements Serializable


Package net.sf.ehcache.pool.sizeof

Class net.sf.ehcache.pool.sizeof.MaxDepthExceededException extends RuntimeException implements Serializable

Serialized Fields

measuredSize

long measuredSize

Package net.sf.ehcache.search

Class net.sf.ehcache.search.SearchException extends CacheException implements Serializable

serialVersionUID: 6942653724476318512L


Package net.sf.ehcache.search.aggregator

Class net.sf.ehcache.search.aggregator.AggregatorException extends SearchException implements Serializable

serialVersionUID: 6942653724476318512L


Package net.sf.ehcache.search.attribute

Class net.sf.ehcache.search.attribute.AttributeExtractorException extends SearchException implements Serializable

serialVersionUID: 5066522240394222152L

Class net.sf.ehcache.search.attribute.JavaBeanAttributeExtractor extends Object implements Serializable

Serialized Fields

beanProperty

String beanProperty

Class net.sf.ehcache.search.attribute.KeyObjectAttributeExtractor extends Object implements Serializable

Class net.sf.ehcache.search.attribute.ReflectionAttributeExtractor extends Object implements Serializable

Serialized Fields

parts

net.sf.ehcache.search.attribute.ReflectionAttributeExtractor.Part[] parts

start

net.sf.ehcache.search.attribute.ReflectionAttributeExtractor.StartType start

Class net.sf.ehcache.search.attribute.UnknownAttributeException extends SearchException implements Serializable

Class net.sf.ehcache.search.attribute.ValueObjectAttributeExtractor extends Object implements Serializable


Package net.sf.ehcache.store

Class net.sf.ehcache.store.LruMemoryStore.SpoolingLinkedHashMap extends LinkedHashMap implements Serializable

Class net.sf.ehcache.store.MemoryStoreEvictionPolicy extends Object implements Serializable

Serialized Fields

myName

String myName

Package net.sf.ehcache.store.chm

Class net.sf.ehcache.store.chm.SelectableConcurrentHashMap.Segment extends ReentrantReadWriteLock implements Serializable

Serialized Fields

count

int count
The number of elements in this segment's region.


modCount

int modCount
Number of updates that alter the size of the table. This is used during bulk-read methods to make sure they see a consistent snapshot: If modCounts change during a traversal of segments computing size or checking containsValue, then we might have an inconsistent view of state so (usually) must retry.


threshold

int threshold
The table is rehashed when its size exceeds this threshold. (The value of this field is always (int)(capacity * loadFactor).)


table

SelectableConcurrentHashMap.HashEntry[] table
The per-segment table.


loadFactor

float loadFactor
The load factor for the hash table. Even though this value is same for all segments, it is replicated to avoid needing links to outer object.

 

evictionIterator

Iterator<E> evictionIterator

Package net.sf.ehcache.store.compound

Class net.sf.ehcache.store.compound.ImmutableValueElementCopyStrategy extends Object implements Serializable

serialVersionUID: 6938731518478806173L

Serialized Fields

copyStrategy

ReadWriteSerializationCopyStrategy copyStrategy

Class net.sf.ehcache.store.compound.LegacyCopyStrategyAdapter extends Object implements Serializable

serialVersionUID: -6986893869400882078L

Serialized Fields

legacyCopyStrategy

CopyStrategy legacyCopyStrategy

Class net.sf.ehcache.store.compound.NullReadWriteCopyStrategy extends Object implements Serializable

serialVersionUID: -3210079128116741621L

Class net.sf.ehcache.store.compound.ReadWriteSerializationCopyStrategy extends Object implements Serializable

serialVersionUID: 2659269742281205622L

Class net.sf.ehcache.store.compound.SerializationCopyStrategy extends Object implements Serializable

serialVersionUID: -7932063007392582487L

Serialized Fields

copyStrategy

ReadWriteSerializationCopyStrategy copyStrategy

Package net.sf.ehcache.store.disk

Class net.sf.ehcache.store.disk.DiskStorageFactory.DiskMarker extends DiskStorageFactory.DiskSubstitute implements Serializable

Serialized Fields

key

Object key

position

long position

size

int size

hitCount

long hitCount

expiry

long expiry

Class net.sf.ehcache.store.disk.Segment extends ReentrantReadWriteLock implements Serializable

Serialized Fields

count

int count
Count of elements in the map.

A volatile reference is needed here for the same reasons as in the table reference.


modCount

int modCount
Mod-count used to track concurrent modifications when doing size calculations or iterating over the store.

Note that we don't actually have any iterators yet...


disk

DiskStorageFactory disk
The primary substitute factory.

This is the substitute type used to store Elements when they are first added to the store.


table

net.sf.ehcache.store.disk.HashEntry[] table
Table of HashEntry linked lists, indexed by the least-significant bits of the spread-hash value.

A volatile reference is needed to ensure the visibility of table changes made during rehash operations to size operations. Key operations are done under read-locks so there is no need for volatility in that regard. Hence if we switched to read-locked size operations, we wouldn't need a volatile reference here.


threshold

int threshold
Size at which the next rehashing of this Segment should occur


onHeapPoolAccessor

PoolAccessor<T extends PoolParticipant> onHeapPoolAccessor

onDiskPoolAccessor

PoolAccessor<T extends PoolParticipant> onDiskPoolAccessor

cacheEventNotificationService

RegisteredEventListeners cacheEventNotificationService

cachePinned

boolean cachePinned

evictionObserver

org.terracotta.statistics.observer.OperationObserver<T extends Enum<T>> evictionObserver

Class net.sf.ehcache.store.disk.StoreUpdateException extends CacheWriterManagerException implements Serializable

Serialized Fields

update

boolean update

Package net.sf.ehcache.terracotta

Class net.sf.ehcache.terracotta.TerracottaNotRunningException extends CacheException implements Serializable


Package net.sf.ehcache.transaction

Class net.sf.ehcache.transaction.DeadLockException extends TransactionException implements Serializable

Class net.sf.ehcache.transaction.ExpiredTransactionIDImpl extends TransactionIDImpl implements Serializable

Class net.sf.ehcache.transaction.SoftLockID extends Object implements Serializable

Serialized Fields

transactionID

TransactionID transactionID

key

Object key

newElement

Element newElement

oldElement

Element oldElement

Class net.sf.ehcache.transaction.TransactionException extends CacheException implements Serializable

Class net.sf.ehcache.transaction.TransactionIDImpl extends Object implements Serializable

Serialized Fields

id

int id

Class net.sf.ehcache.transaction.TransactionIDNotFoundException extends TransactionException implements Serializable

Class net.sf.ehcache.transaction.TransactionIDSerializedForm extends Object implements Serializable

Serialization Methods

readResolve

private Object readResolve()
Serialized Fields

cacheManagerName

String cacheManagerName

clusterUUID

String clusterUUID

ownerID

String ownerID

creationTime

long creationTime

id

int id

Class net.sf.ehcache.transaction.TransactionInterruptedException extends TransactionException implements Serializable

Class net.sf.ehcache.transaction.TransactionTimeoutException extends TransactionException implements Serializable

Class net.sf.ehcache.transaction.XidTransactionIDSerializedForm extends Object implements Serializable

Serialization Methods

readResolve

private Object readResolve()
Serialized Fields

cacheManagerName

String cacheManagerName

cacheName

String cacheName

ownerID

String ownerID

xid

Xid xid

Package net.sf.ehcache.transaction.xa

Class net.sf.ehcache.transaction.xa.EhcacheXAException extends XAException implements Serializable

Class net.sf.ehcache.transaction.xa.ExpiredXidTransactionIDImpl extends XidTransactionIDImpl implements Serializable

Class net.sf.ehcache.transaction.xa.OptimisticLockFailureException extends TransactionException implements Serializable

Class net.sf.ehcache.transaction.xa.SerializableXid extends Object implements Serializable

Serialized Fields

formatId

int formatId

globalTransactionId

byte[] globalTransactionId

branchQualifier

byte[] branchQualifier

Class net.sf.ehcache.transaction.xa.XidTransactionIDImpl extends Object implements Serializable

Serialized Fields

xid

SerializableXid xid

cacheName

String cacheName

Package net.sf.ehcache.util.concurrent

Class net.sf.ehcache.util.concurrent.ConcurrentHashMap.KeySetView extends net.sf.ehcache.util.concurrent.ConcurrentHashMap.CHMView<K,V> implements Serializable

serialVersionUID: 7249069246763182397L

Serialized Fields

value

Object value

Class net.sf.ehcache.util.concurrent.LongAdder extends net.sf.ehcache.util.concurrent.Striped64 implements Serializable

serialVersionUID: 7249069246863182397L

Serialization Methods

readObject

private void readObject(ObjectInputStream s)
                 throws IOException,
                        ClassNotFoundException
Throws:
IOException
ClassNotFoundException

writeObject

private void writeObject(ObjectOutputStream s)
                  throws IOException
Throws:
IOException

Class net.sf.ehcache.util.concurrent.ThreadLocalRandom extends Random implements Serializable

serialVersionUID: -5851777807851030925L

Serialized Fields

rnd

long rnd
The random seed. We can't use super.seed.


initialized

boolean initialized
Initialization flag to permit calls to setSeed to succeed only while executing the Random constructor. We can't allow others since it would cause setting seed in one part of a program to unintentionally impact other usages by the thread.


pad0

long pad0

pad1

long pad1

pad2

long pad2

pad3

long pad3

pad4

long pad4

pad5

long pad5

pad6

long pad6

pad7

long pad7

Package net.sf.ehcache.util.counter

Class net.sf.ehcache.util.counter.CounterImpl extends Object implements Serializable

Serialized Fields

value

AtomicLong value

Package net.sf.ehcache.util.counter.sampled

Class net.sf.ehcache.util.counter.sampled.SampledCounterImpl extends CounterImpl implements Serializable

Serialized Fields

history

CircularLossyQueue<T> history
The history of this counter


resetOnSample

boolean resetOnSample
Should the counter reset on each sample?


samplerTask

TimerTask samplerTask

intervalMillis

long intervalMillis

Class net.sf.ehcache.util.counter.sampled.SampledRateCounterImpl extends SampledCounterImpl implements Serializable

Serialized Fields

numeratorValue

long numeratorValue

denominatorValue

long denominatorValue

Class net.sf.ehcache.util.counter.sampled.TimeStampedCounterValue extends Object implements Serializable

Serialized Fields

counterValue

long counterValue

timestamp

long timestamp

Package net.sf.ehcache.writer

Class net.sf.ehcache.writer.CacheWriterManagerException extends CacheException implements Serializable


ehcache

Copyright 2001-2017, Terracotta, Inc.