Serialized Form
- 
Package org.apache.commons.jcs3.access.exception- 
Exception org.apache.commons.jcs3.access.exception.CacheExceptionclass CacheException extends RuntimeException implements Serializable- serialVersionUID:
- 8725795372935590265L
 
- 
Exception org.apache.commons.jcs3.access.exception.ConfigurationExceptionclass ConfigurationException extends CacheException implements Serializable- serialVersionUID:
- 6881044536186097055L
 
- 
Exception org.apache.commons.jcs3.access.exception.InvalidArgumentExceptionclass InvalidArgumentException extends CacheException implements Serializable- serialVersionUID:
- -6058373692208755562L
 
- 
Exception org.apache.commons.jcs3.access.exception.InvalidGroupExceptionclass InvalidGroupException extends CacheException implements Serializable- serialVersionUID:
- -5219807114008843480L
 
- 
Exception org.apache.commons.jcs3.access.exception.InvalidHandleExceptionclass InvalidHandleException extends CacheException implements Serializable- serialVersionUID:
- -5947822454839845924L
 
- 
Exception org.apache.commons.jcs3.access.exception.ObjectExistsExceptionclass ObjectExistsException extends CacheException implements Serializable- serialVersionUID:
- -3779745827993383872L
 
- 
Exception org.apache.commons.jcs3.access.exception.ObjectNotFoundExceptionclass ObjectNotFoundException extends CacheException implements Serializable- serialVersionUID:
- 5684353421076546842L
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary- 
Class org.apache.commons.jcs3.auxiliary.AbstractAuxiliaryCacheAttributesclass AbstractAuxiliaryCacheAttributes extends Object implements Serializable- serialVersionUID:
- -6594609334959187673L
 - 
Serialized Fields- 
cacheNameString cacheName cacheName
- 
eventQueuePoolNameString eventQueuePoolName Named when pooled
- 
eventQueueTypeICacheEventQueue.QueueType eventQueueType eventQueueType -- pooled, or single threaded
- 
nameString name name
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.disk- 
Class org.apache.commons.jcs3.auxiliary.disk.AbstractDiskCacheAttributesclass AbstractDiskCacheAttributes extends AbstractAuxiliaryCacheAttributes implements Serializable- serialVersionUID:
- 8306631920391711229L
 - 
Serialized Fields- 
allowRemoveAllboolean allowRemoveAll if this is false, we will not execute remove all
- 
diskLimitTypeIDiskCacheAttributes.DiskLimitType diskLimitType Type of disk limit: SIZE or COUNT
- 
diskPathFile diskPath path to disk
- 
maxPurgatorySizeint maxPurgatorySize default to 5000
- 
shutdownSpoolTimeLimitint shutdownSpoolTimeLimit This default determines how long the shutdown will wait for the key spool and data defrag to finish.
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.disk.PurgatoryElement- serialVersionUID:
- -8152034342684135628L
 - 
Serialized Fields- 
cacheElementICacheElement<K, V> cacheElement Wrapped cache Element
- 
spoolableboolean spoolable Is the element ready to be spooled?
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.disk.behavior
- 
Package org.apache.commons.jcs3.auxiliary.disk.block- 
Class org.apache.commons.jcs3.auxiliary.disk.block.BlockDiskCacheAttributesclass BlockDiskCacheAttributes extends AbstractDiskCacheAttributes implements Serializable- serialVersionUID:
- 6568840097657265989L
 - 
Serialized Fields- 
blockSizeBytesint blockSizeBytes The size per block in bytes.
- 
keyPersistenceIntervalSecondslong keyPersistenceIntervalSeconds The keys will be persisted at this interval. -1 mean never.
- 
maxKeySizeint maxKeySize -1 means no limit.
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.disk.block.BlockDiskElementDescriptorclass BlockDiskElementDescriptor extends Object implements Externalizable- serialVersionUID:
- -1400659301208101411L
 - 
Serialization Methods- 
readExternalSaves on reflection.(non-Javadoc) 
- 
writeExternalSaves on reflection.(non-Javadoc) - Throws:
- IOException
- See Also:
 
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.disk.indexed- 
Class org.apache.commons.jcs3.auxiliary.disk.indexed.IndexedDiskCache.PositionComparatorclass PositionComparator extends Object implements Serializable- serialVersionUID:
- -8387365338590814113L
 
- 
Class org.apache.commons.jcs3.auxiliary.disk.indexed.IndexedDiskCacheAttributesclass IndexedDiskCacheAttributes extends AbstractDiskCacheAttributes implements Serializable- serialVersionUID:
- -2190863599358782950L
 - 
Serialized Fields- 
clearDiskOnStartupboolean clearDiskOnStartup Should we clear the disk on startup. If true the contents of disk are cleared.
- 
maxKeySizeint maxKeySize -1 means no limit.
- 
optimizeAtRemoveCountint optimizeAtRemoveCount default to -1, i.e., don't optimize until shutdown
- 
optimizeOnShutdownboolean optimizeOnShutdown Should we optimize on shutdown.
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.disk.indexed.IndexedDiskElementDescriptorclass IndexedDiskElementDescriptor extends Object implements Serializable- serialVersionUID:
- -3029163572847659450L
 - 
Serialized Fields- 
lenint len Number of bytes the serialized form of the cache data takes.
- 
poslong pos Position of the cache data entry on disk.
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.disk.jdbc- 
Class org.apache.commons.jcs3.auxiliary.disk.jdbc.JDBCDiskCacheAttributesclass JDBCDiskCacheAttributes extends AbstractDiskCacheAttributes implements Serializable- serialVersionUID:
- -6535808344813320062L
 - 
Serialized Fields- 
connectionPoolNameString connectionPoolName If a pool name is supplied, the manager will attempt to load it. It should be configured in a separate section as follows. Assuming the name is "MyPool":jcs.jdbcconnectionpool.MyPool.attributes.userName=MyUserName jcs.jdbcconnectionpool.MyPool.attributes.password=MyPassword jcs.jdbcconnectionpool.MyPool.attributes.url=MyUrl jcs.jdbcconnectionpool.MyPool.attributes.maxActive=MyMaxActive jcs.jdbcconnectionpool.MyPool.attributes.driverClassName=MyDriverClassName 
- 
databaseString database The name of the database.
- 
driverClassNameString driverClassName The driver
- 
jndiPathString jndiPath The JNDI path.
- 
jndiTTLlong jndiTTL The time between two JNDI lookups
- 
maxTotalint maxTotal Max connections allowed
- 
passwordString password DB password
- 
shrinkerIntervalSecondsint shrinkerIntervalSeconds How often should we remove expired.
- 
tableNameString tableName The table name
- 
testBeforeInsertboolean testBeforeInsert If false we will insert and if it fails we will update.
- 
urlString url URL for the db
- 
useDiskShrinkerboolean useDiskShrinker Should we remove expired in the background.
- 
userNameString userName DB username
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.disk.jdbc.TableStateclass TableState extends Object implements Serializable- serialVersionUID:
- -6625081552084964885L
 - 
Serialized Fields- 
stateint state we might want to add error
- 
tableNameString tableName Name of the table whose state this reflects.
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.disk.jdbc.mysql- 
Class org.apache.commons.jcs3.auxiliary.disk.jdbc.mysql.MySQLDiskCacheAttributesclass MySQLDiskCacheAttributes extends JDBCDiskCacheAttributes implements Serializable- serialVersionUID:
- -6535808344813320061L
 - 
Serialized Fields- 
balkDuringOptimizationboolean balkDuringOptimization If true, we will balk, that is return null during optimization rather than block.
- 
optimizationScheduleString optimizationSchedule For now this is a simple comma delimited list of HH:MM:SS times to optimize the table. If none is supplied, then no optimizations will be performed.In the future we can add a chron like scheduling system. This is to meet a pressing current need. 03:01,15:00 will cause the optimizer to run at 3 am and at 3 pm. 
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.lateral- 
Class org.apache.commons.jcs3.auxiliary.lateral.LateralCacheAttributesclass LateralCacheAttributes extends AbstractAuxiliaryCacheAttributes implements Serializable- serialVersionUID:
- -3408449508837393660L
 - 
Serialized Fields- 
httpListenerPortint httpListenerPort this needs to change
- 
httpServerString httpServer used to identify the service that this manager will be operating on
- 
httpServersString httpServers The http servers
- 
putOnlyModeboolean putOnlyMode disables gets from laterals
- 
receiveboolean receive do we receive and broadcast or only broadcast this is useful when you don't want to get any notifications
- 
transmissionTypeILateralCacheAttributes.Type transmissionType indicates the lateral type, this needs to change
- 
udpMulticastAddrString udpMulticastAddr this needs to change
- 
udpMulticastPortint udpMulticastPort this needs to change
- 
zombieQueueMaxSizeint zombieQueueMaxSize If the primary fails, we will queue items before reconnect. This limits the number of items that can be queued.
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.lateral.LateralElementDescriptorclass LateralElementDescriptor extends Object implements Serializable- serialVersionUID:
- 5268222498076063575L
 - 
Serialized Fields- 
ceICacheElement<K, V> ce The Cache Element that we are distributing.
- 
commandLateralCommand command The operation has been requested by the client.
- 
requesterIdlong requesterId The id of the source of the request. This is used to prevent infinite loops.
- 
valHashCodeint valHashCode The hash code value for this element.
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.lateral.behavior
- 
Package org.apache.commons.jcs3.auxiliary.lateral.socket.tcp- 
Class org.apache.commons.jcs3.auxiliary.lateral.socket.tcp.TCPLateralCacheAttributesclass TCPLateralCacheAttributes extends LateralCacheAttributes implements Serializable- serialVersionUID:
- 1077889204513905220L
 - 
Serialized Fields- 
allowGetboolean allowGet can we go laterally for a get
- 
allowPutboolean allowPut can we put
- 
filterRemoveByHashCodeboolean filterRemoveByHashCode don't remove it the hash code is the same
- 
issueRemoveOnPutboolean issueRemoveOnPut call remove when there is a put
- 
openTimeOutint openTimeOut Only block for openTimeOut seconds before timing out on startup.
- 
socketTimeOutint socketTimeOut Only block for socketTimeOut seconds before timing out on a read.
- 
tcpListenerHostString tcpListenerHost The host
- 
tcpListenerPortint tcpListenerPort The port
- 
tcpServerString tcpServer used to identify the service that this manager will be operating on
- 
tcpServersString tcpServers TCP --------------------------------------------
- 
udpDiscoveryAddrString udpDiscoveryAddr udp discovery for tcp server
- 
udpDiscoveryEnabledboolean udpDiscoveryEnabled discovery switch
- 
udpDiscoveryPortint udpDiscoveryPort discovery port
- 
udpTTLint udpTTL udp datagram TTL
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.lateral.socket.tcp.behavior
- 
Package org.apache.commons.jcs3.auxiliary.remote- 
Class org.apache.commons.jcs3.auxiliary.remote.CommonRemoteCacheAttributesclass CommonRemoteCacheAttributes extends AbstractAuxiliaryCacheAttributes implements Serializable- serialVersionUID:
- -1555143736942374000L
 - 
Serialized Fields- 
clusterServersString clusterServers Cluster chain
- 
getOnlyboolean getOnly Can we receive from or put to the remote. this probably shouldn't be used. Use receive.
- 
localClusterConsistencyboolean localClusterConsistency Should we put and get from the clusters.
- 
locationRemoteLocation location server host and port
- 
remoteServiceNameString remoteServiceName The service name
- 
remoteTypeRemoteType remoteType THe type of remote cache, local or cluster
- 
removeUponRemotePutboolean removeUponRemotePut Should we issue a local remove if we get a put from a remote server
- 
rmiSocketFactoryTimeoutMillisint rmiSocketFactoryTimeoutMillis read and connect timeout
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.remote.RemoteCacheAttributesclass RemoteCacheAttributes extends CommonRemoteCacheAttributes implements Serializable- serialVersionUID:
- -1555143736942374000L
 - 
Serialized Fields- 
failoverIndexint failoverIndex what failover server we are connected to.
- 
failoversList<RemoteLocation> failovers List of failover server addresses
- 
failoverServersString failoverServers Failover servers will be used by local caches one at a time. Listeners will be registered with all cluster servers. If we add a get from cluster attribute we will have the ability to chain clusters and have them get from each other.
- 
getTimeoutMillisint getTimeoutMillis must be greater than 0 for a pool to be used.
- 
localPortint localPort callback
- 
receiveboolean receive Can we receive from the server. You might have a 0 local store and keep everything on the remote. If so, you don't want to be notified of updates.
- 
threadPoolNameString threadPoolName default name is remote_cache_client
- 
zombieQueueMaxSizeint zombieQueueMaxSize If the primary fails, we will queue items before reconnect. This limits the number of items that can be queued.
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.remote.behavior
- 
Package org.apache.commons.jcs3.auxiliary.remote.http.client- 
Class org.apache.commons.jcs3.auxiliary.remote.http.client.RemoteHttpCacheAttributesclass RemoteHttpCacheAttributes extends RemoteCacheAttributes implements Serializable- serialVersionUID:
- -5944327125140505212L
 - 
Serialized Fields- 
connectionTimeoutMillisint connectionTimeoutMillis The socket connections timeout
- 
httpVersionString httpVersion http version to use.
- 
includeCacheNameAsParameterboolean includeCacheNameAsParameter The cache name will be included on the parameters
- 
includeKeysAndPatternsAsParameterboolean includeKeysAndPatternsAsParameter keys and patterns will be included in the parameters
- 
includeRequestTypeasAsParameterboolean includeRequestTypeasAsParameter keys and patterns will be included in the parameters
- 
maxConnectionsPerHostint maxConnectionsPerHost The max connections allowed per host
- 
remoteHttpClientClassNameString remoteHttpClientClassName This allows users to inject their own client implementation.
- 
socketTimeoutMillisint socketTimeoutMillis The socket timeout.
- 
urlString url The complete URL to the service.
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.remote.http.server- 
Class org.apache.commons.jcs3.auxiliary.remote.http.server.RemoteHttpCacheServerAttributesclass RemoteHttpCacheServerAttributes extends AbstractAuxiliaryCacheAttributes implements Serializable- serialVersionUID:
- -3987239306108780496L
 - 
Serialized Fields- 
allowClusterGetboolean allowClusterGet Can a cluster remote get from other remotes
- 
localClusterConsistencyboolean localClusterConsistency Can a cluster remote put to other remotes
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.remote.http.server.RemoteHttpCacheServletclass RemoteHttpCacheServlet extends HttpServlet implements Serializable- serialVersionUID:
- 8752849397531933346L
 - 
Serialized Fields- 
serviceCallsint serviceCalls Number of service calls.
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.remote.server- 
Class org.apache.commons.jcs3.auxiliary.remote.server.RemoteCacheServerclass RemoteCacheServer extends UnicastRemoteObject implements Serializable- serialVersionUID:
- -8072345435941473116L
 - 
Serialized Fields- 
idIPMapConcurrentMap<Long, String> idIPMap relates listener id with an ip address
- 
idTypeMapConcurrentMap<Long, RemoteType> idTypeMap relates listener id with a type
- 
listenerIdint[] listenerId Used to get the next listener id.
- 
putsint puts Number of puts into the cache.
- 
remoteCacheServerAttributesIRemoteCacheServerAttributes remoteCacheServerAttributes Configuration settings.
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.remote.server.RemoteCacheServerAttributesclass RemoteCacheServerAttributes extends CommonRemoteCacheAttributes implements Serializable- serialVersionUID:
- -2741662082869155365L
 - 
Serialized Fields- 
allowClusterGetboolean allowClusterGet Can a cluster remote get from other remotes
- 
configFileNameString configFileName The config file, the initialization is multistage. Remote cache then composite cache.
- 
registryKeepAliveDelayMillislong registryKeepAliveDelayMillis The delay between runs
- 
servicePortint servicePort port the server will listen to
- 
startRegistryboolean startRegistry Should we start the registry
- 
useRegistryKeepAliveboolean useRegistryKeepAlive Should we try to keep the registry alive
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.remote.server.RemoteCacheStartupServletclass RemoteCacheStartupServlet extends HttpServlet implements Serializable- serialVersionUID:
- 1L
 
- 
Class org.apache.commons.jcs3.auxiliary.remote.server.TimeoutConfigurableRMISocketFactoryclass TimeoutConfigurableRMISocketFactory extends RMISocketFactory implements Serializable- serialVersionUID:
- 1489909775271203334L
 - 
Serialized Fields- 
openTimeoutint openTimeout The socket open timeout
- 
readTimeoutint readTimeout The socket read timeout
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.auxiliary.remote.server.behavior
- 
Package org.apache.commons.jcs3.auxiliary.remote.value- 
Class org.apache.commons.jcs3.auxiliary.remote.value.RemoteCacheRequestclass RemoteCacheRequest extends Object implements Serializable- serialVersionUID:
- -8858447417390442569L
 - 
Serialized Fields- 
cacheElementICacheElement<K, V> cacheElement The ICacheEleemnt, if this request contains a value. Only update requests will have this.
- 
cacheNameString cacheName The name of the region
- 
keyK key The key, if this request has a key.
- 
keySetSet<K> keySet The keySet, if this request has a keySet. Only getMultiple requests.
- 
patternString pattern The pattern, if this request uses a pattern. Only getMatching requests.
- 
requesterIdlong requesterId Used to identify the source. Same as listener id on the client side.
- 
requestTypeRemoteRequestType requestType The request type specifies the type of request: get, put, remove, . .
 
- 
 
- 
Class org.apache.commons.jcs3.auxiliary.remote.value.RemoteCacheResponseclass RemoteCacheResponse extends Object implements Serializable- serialVersionUID:
- -8858447417390442568L
 
 
- 
- 
Package org.apache.commons.jcs3.engine- 
Class org.apache.commons.jcs3.engine.CacheElementclass CacheElement extends Object implements Serializable- serialVersionUID:
- -6062305728297627263L
 - 
Serialized Fields- 
attrIElementAttributes attr These attributes hold information about the element and what it is allowed to do.
- 
cacheNameString cacheName The name of the cache region. This is a namespace.
- 
keyK key This is the cache key by which the value can be referenced.
- 
valV val This is the cached value, reference by the key.
 
- 
 
- 
Class org.apache.commons.jcs3.engine.CacheElementSerialized- serialVersionUID:
- -7265084818647601874L
 - 
Serialized Fields- 
serializedValuebyte[] serializedValue The serialized value.
 
- 
 
- 
Class org.apache.commons.jcs3.engine.CompositeCacheAttributesclass CompositeCacheAttributes extends Object implements Serializable- serialVersionUID:
- 6754049978134196787L
 - 
Serialized Fields- 
cacheNameString cacheName The name of this cache region.
- 
diskUsagePatternICompositeCacheAttributes.DiskUsagePattern diskUsagePattern Set via DISK_USAGE_PATTERN_NAME
- 
maxMemoryIdleTimeSecondslong maxMemoryIdleTimeSeconds maxMemoryIdleTimeSeconds
- 
maxObjsint maxObjs The maximum objects that the memory cache will be allowed to hold.
- 
maxSpoolPerRunint maxSpoolPerRun The maximum number the shrinker will spool to disk per run.
- 
memoryCacheNameString memoryCacheName The name of the memory cache implementation class.
- 
shrinkerIntervalSecondslong shrinkerIntervalSeconds shrinkerIntervalSeconds
- 
spoolChunkSizeint spoolChunkSize How many to spool to disk at a time.
- 
useDiskboolean useDisk Whether we should use a disk cache if it is configured.
- 
useLateralboolean useLateral allow lateral caches
- 
useMemoryShrinkerboolean useMemoryShrinker Whether or not we should run the memory shrinker thread.
- 
useRemoteboolean useRemote allow remote caches
 
- 
 
- 
Class org.apache.commons.jcs3.engine.ElementAttributesclass ElementAttributes extends Object implements Serializable- serialVersionUID:
- 7814990748035017441L
 - 
Serialized Fields- 
createTimelong createTime The creation time. This is used to enforce the max life.
- 
IS_ETERNALboolean IS_ETERNAL You can turn off expiration by setting this to true. This causes the cache to bypass both max life and idle time expiration.
- 
IS_LATERALboolean IS_LATERAL Is this item laterally distributable
- 
IS_REMOTEboolean IS_REMOTE Can this item be sent to the remote cache
- 
IS_SPOOLboolean IS_SPOOL Can this item be flushed to disk
- 
lastAccessTimelong lastAccessTime The last access time. This is used to enforce the max idel time.
- 
maxIdleTimelong maxIdleTime The maximum time an entry can be idle. Setting this to -1 causes the idle time check to be ignored.
- 
maxLifelong maxLife Max life seconds
- 
sizeint size The byte size of the field. Must be manually set.
- 
timeFactorlong timeFactor 
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.engine.behavior
- 
Package org.apache.commons.jcs3.engine.control.event- 
Class org.apache.commons.jcs3.engine.control.event.ElementEventclass ElementEvent extends EventObject implements Serializable- serialVersionUID:
- -5364117411457467056L
 - 
Serialized Fields- 
elementEventElementEventType elementEvent default event code
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.engine.control.event.behavior
- 
Package org.apache.commons.jcs3.engine.control.group- 
Class org.apache.commons.jcs3.engine.control.group.GroupAttrNameclass GroupAttrName extends Object implements Serializable- serialVersionUID:
- 1586079686300744198L
 
- 
Class org.apache.commons.jcs3.engine.control.group.GroupIdclass GroupId extends Object implements Serializable- serialVersionUID:
- 4626368486444860133L
 
 
- 
- 
Package org.apache.commons.jcs3.engine.logging- 
Class org.apache.commons.jcs3.engine.logging.CacheEventclass CacheEvent extends Object implements Serializable- serialVersionUID:
- -5913139566421714330L
 - 
Serialized Fields- 
createTimelong createTime The time at which this object was created.
- 
eventNameString eventName The event name: update, get, remove, etc.
- 
keyK key The key that was put or retrieved.
- 
optionalDetailsString optionalDetails disk location, ip, etc.
- 
regionString region The cache region
- 
sourceString source The auxiliary or other source of the event.
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.engine.logging.behavior
- 
Package org.apache.commons.jcs3.engine.match- 
Class org.apache.commons.jcs3.engine.match.KeyMatcherPatternImplclass KeyMatcherPatternImpl extends Object implements Serializable- serialVersionUID:
- 6667352064144381264L
 
 
- 
- 
Package org.apache.commons.jcs3.engine.match.behavior
- 
Package org.apache.commons.jcs3.engine.memory.lru- 
Class org.apache.commons.jcs3.engine.memory.lru.LHMLRUMemoryCache.LHMSpooler- serialVersionUID:
- -1255907868906762484L
 
 
- 
- 
Package org.apache.commons.jcs3.engine.memory.util- 
Class org.apache.commons.jcs3.engine.memory.util.MemoryElementDescriptorclass MemoryElementDescriptor extends DoubleLinkedListNode<ICacheElement<K,V>> implements Serializable - serialVersionUID:
- -1905161209035522460L
 
- 
Class org.apache.commons.jcs3.engine.memory.util.SoftReferenceElementDescriptor- serialVersionUID:
- -1905161209035522460L
 
 
- 
- 
Package org.apache.commons.jcs3.engine.stats- 
Class org.apache.commons.jcs3.engine.stats.CacheStatsclass CacheStats extends Stats implements Serializable- serialVersionUID:
- 529914708798168590L
 
- 
Class org.apache.commons.jcs3.engine.stats.StatElementclass StatElement extends Object implements Serializable- serialVersionUID:
- -2982373725267618092L
 
- 
Class org.apache.commons.jcs3.engine.stats.Statsclass Stats extends Object implements Serializable- serialVersionUID:
- 227327902875154010L
 - 
Serialized Fields- 
statsList<IStatElement<?>> stats The stats
- 
typeNameString typeName The type of stat
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.engine.stats.behavior
- 
Package org.apache.commons.jcs3.utils.config- 
Exception org.apache.commons.jcs3.utils.config.PropertySetterExceptionclass PropertySetterException extends Exception implements Serializable- serialVersionUID:
- -210271658004609028L
 - 
Serialized Fields- 
rootCauseThrowable rootCause Description of the Field
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.utils.discovery- 
Class org.apache.commons.jcs3.utils.discovery.DiscoveredServiceclass DiscoveredService extends Object implements Serializable- serialVersionUID:
- -7810164772089509751L
 
- 
Class org.apache.commons.jcs3.utils.discovery.UDPDiscoveryMessageclass UDPDiscoveryMessage extends Object implements Serializable- serialVersionUID:
- -5332377899560951793L
 - 
Serialized Fields- 
cacheNamesArrayList<String> cacheNames Names of regions
- 
hostString host UDP host
- 
messageTypeUDPDiscoveryMessage.BroadcastType messageType The message type
- 
portint port udp port
- 
requesterIdlong requesterId Id of the requester, allows self-filtration
 
- 
 
 
- 
- 
Package org.apache.commons.jcs3.utils.struct- 
Class org.apache.commons.jcs3.utils.struct.DoubleLinkedListNodeclass DoubleLinkedListNode extends Object implements Serializable- serialVersionUID:
- -1114934407695836097L
 - 
Serialized Fields- 
nextDoubleLinkedListNode<T> next Double Linked list references
- 
payloadT payload The object in the node.
- 
prevDoubleLinkedListNode<T> prev Double Linked list references
 
- 
 
- 
Class org.apache.commons.jcs3.utils.struct.LRUElementDescriptor- serialVersionUID:
- 8249555756363020156L
 - 
Serialized Fields- 
keyK key The key value
 
- 
 
 
-