Serialized Form


Package org.apache.jcs.access.exception

Class org.apache.jcs.access.exception.CacheException extends java.lang.Exception implements Serializable

serialVersionUID: 8725795372935590265L

Class org.apache.jcs.access.exception.InvalidArgumentException extends CacheException implements Serializable

serialVersionUID: -6058373692208755562L

Class org.apache.jcs.access.exception.InvalidGroupException extends CacheException implements Serializable

serialVersionUID: -5219807114008843480L

Class org.apache.jcs.access.exception.InvalidHandleException extends CacheException implements Serializable

serialVersionUID: -5947822454839845924L

Class org.apache.jcs.access.exception.NotARetrievableObjectException extends CacheException implements Serializable

serialVersionUID: 4501711027054012410L

Class org.apache.jcs.access.exception.NullObjectException extends CacheException implements Serializable

serialVersionUID: 827922769279844194L

Class org.apache.jcs.access.exception.ObjectExistsException extends CacheException implements Serializable

serialVersionUID: -3779745827993383872L

Class org.apache.jcs.access.exception.ObjectNotFoundException extends CacheException implements Serializable

serialVersionUID: 5684353421076546842L


Package org.apache.jcs.access.monitor

Class org.apache.jcs.access.monitor.MonitorAccess extends java.lang.Object implements Serializable

serialVersionUID: 1002037665133774391L

Serialized Fields

cacheMgr

CompositeCacheManager cacheMgr
Description of the Field


Package org.apache.jcs.admin.servlet

Class org.apache.jcs.admin.servlet.JCSAdminServlet extends org.apache.velocity.servlet.VelocityServlet implements Serializable

serialVersionUID: -5519844149238645275L


Package org.apache.jcs.auxiliary

Class org.apache.jcs.auxiliary.AbstractAuxiliaryCacheAttributes extends java.lang.Object implements Serializable

Serialized Fields

cacheName

java.lang.String cacheName
cacheName


name

java.lang.String name
name


eventQueueType

int eventQueueType
eventQueueType -- pooled or single threaded


eventQueuePoolName

java.lang.String eventQueuePoolName
Named when pooled


Package org.apache.jcs.auxiliary.disk

Class org.apache.jcs.auxiliary.disk.AbstractDiskCache extends java.lang.Object implements Serializable

Serialized Fields

dcattr

IDiskCacheAttributes dcattr
Generic disk cache attributes


purgatory

java.util.Map<K,V> purgatory
Map where elements are stored between being added to this cache and actually spooled to disk. This allows puts to the disk cache to return quickly, and the more expensive operation of serializing the elements to persistent storage queued for later.

If the elements are pulled into the memory cache while the are still in purgatory, writing to disk can be cancelled.


cacheEventQueue

ICacheEventQueue cacheEventQueue
The CacheEventQueue where changes will be queued for asynchronous updating of the persistent storage.


alive

boolean alive
Indicates whether the cache is 'alive', defined as having been initialized, but not yet disposed.


cacheName

java.lang.String cacheName
Every cache will have a name, subclasses must set this when they are initialized.


purgHits

int purgHits
DEBUG: Keeps a count of the number of purgatory hits for debug messages


removeAllLock

EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock removeAllLock
We lock here, so that we cannot get an update after a remove all. an individual removal locks the item.

Class org.apache.jcs.auxiliary.disk.AbstractDiskCacheAttributes extends AbstractAuxiliaryCacheAttributes implements Serializable

Serialized Fields

diskPath

java.lang.String diskPath
path to disk


allowRemoveAll

boolean allowRemoveAll
if this is false, we will not execute remove all


maxPurgatorySize

int maxPurgatorySize
default to 5000


shutdownSpoolTimeLimit

int shutdownSpoolTimeLimit
This default determines how long the shutdown will wait for the key spool and data defrag to finish.

Class org.apache.jcs.auxiliary.disk.PurgatoryElement extends java.lang.Object implements Serializable

serialVersionUID: -8152034342684135628L

Serialized Fields

spoolable

boolean spoolable
Is the element ready to be spooled?


cacheElement

ICacheElement cacheElement
Wrapped cache Element


Package org.apache.jcs.auxiliary.disk.behavior

Package org.apache.jcs.auxiliary.disk.block

Class org.apache.jcs.auxiliary.disk.block.BlockDiskCache extends AbstractDiskCache implements Serializable

serialVersionUID: 1L

Serialized Fields

logCacheName

java.lang.String logCacheName
The name to prefix all log messages with.


fileName

java.lang.String fileName
The name of the file to store data.


dataFile

BlockDisk dataFile
The data access object


blockDiskCacheAttributes

BlockDiskCacheAttributes blockDiskCacheAttributes
Attributes governing the behavior of the block disk cache.


rootDirectory

java.io.File rootDirectory
The root directory for keys and data.


keyStore

BlockDiskKeyStore keyStore
Store, loads, and persists the keys


storageLock

EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock storageLock
Use this lock to synchronize reads and writes to the underlying storage mechansism. We don't need a reentrant lock, since we only lock one level.

Class org.apache.jcs.auxiliary.disk.block.BlockDiskCacheAttributes extends AbstractDiskCacheAttributes implements Serializable

serialVersionUID: 6568840097657265989L

Serialized Fields

blockSizeBytes

int blockSizeBytes
The size per block in bytes.


maxKeySize

int maxKeySize
-1 means no limit.


keyPersistenceIntervalSeconds

long keyPersistenceIntervalSeconds
The keys will be persisted at this interval. -1 mean never.

Class org.apache.jcs.auxiliary.disk.block.BlockDiskCacheManager extends java.lang.Object implements Serializable

serialVersionUID: -4153287154512274626L

Serialized Fields

caches

java.util.Hashtable<K,V> caches
block disks for a region.


defaultCacheAttributes

BlockDiskCacheAttributes defaultCacheAttributes
Attributes.

Class org.apache.jcs.auxiliary.disk.block.BlockDiskElementDescriptor extends java.lang.Object implements Serializable

serialVersionUID: -1400659301208101411L

Serialization Methods

readExternal

public void readExternal(java.io.ObjectInput input)
                  throws java.io.IOException,
                         java.lang.ClassNotFoundException
Saves on reflection.

(non-Javadoc)

Throws:
java.io.IOException
java.lang.ClassNotFoundException
See Also:
Externalizable.readExternal(java.io.ObjectInput)

writeExternal

public void writeExternal(java.io.ObjectOutput output)
                   throws java.io.IOException
Saves on reflection.

(non-Javadoc)

Throws:
java.io.IOException
See Also:
Externalizable.writeExternal(java.io.ObjectOutput)

Package org.apache.jcs.auxiliary.disk.indexed

Class org.apache.jcs.auxiliary.disk.indexed.IndexedDiskCache extends AbstractDiskCache implements Serializable

serialVersionUID: -265035607729729629L

Serialized Fields

logCacheName

java.lang.String logCacheName

fileName

java.lang.String fileName

dataFile

org.apache.jcs.auxiliary.disk.indexed.IndexedDisk dataFile

keyFile

org.apache.jcs.auxiliary.disk.indexed.IndexedDisk keyFile

keyHash

java.util.Map<K,V> keyHash

maxKeySize

int maxKeySize

rafDir

java.io.File rafDir

doRecycle

boolean doRecycle

isRealTimeOptimizationEnabled

boolean isRealTimeOptimizationEnabled

isShutdownOptimizationEnabled

boolean isShutdownOptimizationEnabled

isOptimizing

boolean isOptimizing
are we currenlty optimizing the files


timesOptimized

int timesOptimized

currentOptimizationThread

java.lang.Thread currentOptimizationThread

removeCount

int removeCount
used for counting the number of requests


queueInput

boolean queueInput

queuedPutList

java.util.LinkedList<E> queuedPutList
list where puts made during optimization are made


recycle

SortedPreferentialArray recycle
RECYLCE BIN -- array of empty spots


cattr

IndexedDiskCacheAttributes cattr

recycleCnt

int recycleCnt

startupSize

int startupSize

bytesFree

long bytesFree
the number of bytes free on disk.


hitCount

int hitCount

storageLock

EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock storageLock
Use this lock to synchronize reads and writes to the underlying storage mechansism.

Class org.apache.jcs.auxiliary.disk.indexed.IndexedDiskCacheAttributes extends AbstractDiskCacheAttributes implements Serializable

serialVersionUID: -2190863599358782950L

Serialized Fields

maxKeySize

int maxKeySize
-1 means no limit.


maxRecycleBinSize

int maxRecycleBinSize
Cannot be larger than the max size. If max is less than 0, this will be 5000


optimizeAtRemoveCount

int optimizeAtRemoveCount

optimizeOnShutdown

boolean optimizeOnShutdown

Class org.apache.jcs.auxiliary.disk.indexed.IndexedDiskCacheManager extends java.lang.Object implements Serializable

serialVersionUID: -4153287154512274626L

Serialized Fields

caches

java.util.Hashtable<K,V> caches

defaultCacheAttributes

IndexedDiskCacheAttributes defaultCacheAttributes

Class org.apache.jcs.auxiliary.disk.indexed.IndexedDiskElementDescriptor extends java.lang.Object implements Serializable

serialVersionUID: -3029163572847659450L

Serialized Fields

pos

long pos
Position of the cache data entry on disk.


len

int len
Number of bytes the serialized form of the cache data takes.


Package org.apache.jcs.auxiliary.disk.jdbc

Class org.apache.jcs.auxiliary.disk.jdbc.JDBCDiskCache extends AbstractDiskCache implements Serializable

serialVersionUID: -7169488308515823492L

Serialized Fields

elementSerializer

IElementSerializer elementSerializer

jdbcDiskCacheAttributes

JDBCDiskCacheAttributes jdbcDiskCacheAttributes

updateCount

int updateCount

getCount

int getCount

poolAccess

JDBCDiskCachePoolAccess poolAccess

tableState

TableState tableState

Class org.apache.jcs.auxiliary.disk.jdbc.JDBCDiskCacheAttributes extends AbstractDiskCacheAttributes implements Serializable

serialVersionUID: -6535808344813320062L

Serialized Fields

userName

java.lang.String userName

password

java.lang.String password

url

java.lang.String url

database

java.lang.String database

driverClassName

java.lang.String driverClassName

tableName

java.lang.String tableName

testBeforeInsert

boolean testBeforeInsert

maxActive

int maxActive

shrinkerIntervalSeconds

int shrinkerIntervalSeconds

UseDiskShrinker

boolean UseDiskShrinker

Class org.apache.jcs.auxiliary.disk.jdbc.JDBCDiskCacheManager extends JDBCDiskCacheManagerAbstractTemplate implements Serializable

serialVersionUID: -8258856770927857896L

Serialized Fields

defaultJDBCDiskCacheAttributes

JDBCDiskCacheAttributes defaultJDBCDiskCacheAttributes

Class org.apache.jcs.auxiliary.disk.jdbc.JDBCDiskCacheManagerAbstractTemplate extends java.lang.Object implements Serializable

Serialized Fields

shrinkerDaemon

EDU.oswego.cs.dl.util.concurrent.ClockDaemon shrinkerDaemon
The background disk shrinker, one for all regions.


shrinkerThreadMap

java.util.Map<K,V> shrinkerThreadMap
A map of table name to shrinker threads. This allows each table to have a different setting. It assumes that there is only one jdbc disk cache auxiliary defined per table.

Class org.apache.jcs.auxiliary.disk.jdbc.TableState extends java.lang.Object implements Serializable

serialVersionUID: -6625081552084964885L

Serialized Fields

tableName

java.lang.String tableName
Name of the table whose state this reflects.


state

int state
we might want to add error


Package org.apache.jcs.auxiliary.disk.jdbc.mysql

Class org.apache.jcs.auxiliary.disk.jdbc.mysql.MySQLDiskCache extends JDBCDiskCache implements Serializable

serialVersionUID: -7169488308515823491L

Serialized Fields

mySQLDiskCacheAttributes

MySQLDiskCacheAttributes mySQLDiskCacheAttributes

Class org.apache.jcs.auxiliary.disk.jdbc.mysql.MySQLDiskCacheAttributes extends JDBCDiskCacheAttributes implements Serializable

serialVersionUID: -6535808344813320061L

Serialized Fields

optimizationSchedule

java.lang.String 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.


balkDuringOptimization

boolean balkDuringOptimization
If true, we will balk, that is return null during optimization rather than block.

Balking

Class org.apache.jcs.auxiliary.disk.jdbc.mysql.MySQLDiskCacheManager extends JDBCDiskCacheManagerAbstractTemplate implements Serializable

serialVersionUID: -8258856770927857896L

Serialized Fields

defaultJDBCDiskCacheAttributes

MySQLDiskCacheAttributes defaultJDBCDiskCacheAttributes

daemon

java.util.Timer daemon

Package org.apache.jcs.auxiliary.disk.jdbc.mysql.util

Class org.apache.jcs.auxiliary.disk.jdbc.mysql.util.ScheduleFormatException extends java.lang.Exception implements Serializable

serialVersionUID: 1L


Package org.apache.jcs.auxiliary.lateral

Class org.apache.jcs.auxiliary.lateral.LateralCache extends java.lang.Object implements Serializable

serialVersionUID: 6274549256562382782L

Serialized Fields

cattr

ILateralCacheAttributes cattr

cacheName

java.lang.String cacheName

lateral

ILateralCacheService lateral
either http, socket.udp, or socket.tcp can set in config


monitor

LateralCacheMonitor monitor

Class org.apache.jcs.auxiliary.lateral.LateralCacheAbstractManager extends java.lang.Object implements Serializable

Serialized Fields

caches

java.util.Map<K,V> caches
Each manager instance has caches.


lca

ILateralCacheAttributes lca
Description of the Field


lateralService

ILateralCacheService lateralService
Handle to the lateral cache service; or a zombie handle if failed to connect.


lateralWatch

LateralCacheWatchRepairable lateralWatch
Wrapper of the lateral cache watch service; or wrapper of a zombie service if failed to connect.

Class org.apache.jcs.auxiliary.lateral.LateralCacheAttributes extends AbstractAuxiliaryCacheAttributes implements Serializable

serialVersionUID: -3408449508837393660L

Serialized Fields

transmissionTypeName

java.lang.String transmissionTypeName

transmissionType

int transmissionType

httpServers

java.lang.String httpServers

httpServer

java.lang.String httpServer

httpReceiveServlet

java.lang.String httpReceiveServlet

httpDeleteServlet

java.lang.String httpDeleteServlet

udpMulticastAddr

java.lang.String udpMulticastAddr

udpMulticastPort

int udpMulticastPort

httpListenerPort

int httpListenerPort

jgChannelProperties

java.lang.String jgChannelProperties

putOnlyMode

boolean putOnlyMode

receive

boolean receive

Class org.apache.jcs.auxiliary.lateral.LateralCacheNoWait extends java.lang.Object implements Serializable

serialVersionUID: -7251187566116178475L

Serialized Fields

cache

LateralCache cache

q

ICacheEventQueue q

getCount

int getCount

removeCount

int removeCount

putCount

int putCount

Class org.apache.jcs.auxiliary.lateral.LateralCacheNoWaitFacade extends java.lang.Object implements Serializable

serialVersionUID: -9047687810358008955L

Serialized Fields

noWaits

LateralCacheNoWait[] noWaits
The queuing facade to the client.


cacheName

java.lang.String cacheName

lateralCacheAttributes

ILateralCacheAttributes lateralCacheAttributes

Class org.apache.jcs.auxiliary.lateral.LateralElementDescriptor extends java.lang.Object implements Serializable

serialVersionUID: 5268222498076063575L

Serialized Fields

ce

ICacheElement ce
The Cache Element that we are distributing.


requesterId

long requesterId
The id of the the source of the request. This is used to prevent infinite loops.


command

int command
The operation has been requested by the client.


valHashCode

int valHashCode
The hashcode value for this element.


Package org.apache.jcs.auxiliary.lateral.behavior

Package org.apache.jcs.auxiliary.lateral.socket.tcp

Class org.apache.jcs.auxiliary.lateral.socket.tcp.LateralTCPCacheManager extends LateralCacheAbstractManager implements Serializable

serialVersionUID: -9213011856644392480L

Serialized Fields

lca

ITCPLateralCacheAttributes lca
ITCPLateralCacheAttributes


clients

int clients

lateralService

ILateralCacheService lateralService
Handle to the lateral cache service; or a zombie handle if failed to connect.


lateralWatch

LateralCacheWatchRepairable lateralWatch
Wrapper of the lateral cache watch service; or wrapper of a zombie service if failed to connect.


cacheMgr

ICompositeCacheManager cacheMgr
This is set in the constructor.

Class org.apache.jcs.auxiliary.lateral.socket.tcp.LateralTCPListener extends java.lang.Object implements Serializable

serialVersionUID: -9107062664967131738L

Serialized Fields

receiver

LateralTCPListener.ListenerThread receiver
The socket listener


tcpLateralCacheAttributes

ITCPLateralCacheAttributes tcpLateralCacheAttributes

port

int port

pooledExecutor

EDU.oswego.cs.dl.util.concurrent.PooledExecutor pooledExecutor

putCnt

int putCnt

removeCnt

int removeCnt

getCnt

int getCnt

listenerId

long listenerId
Use the vmid by default. This can be set for testing. If we ever need to run more than one per vm, then we need a new technique.

Class org.apache.jcs.auxiliary.lateral.socket.tcp.TCPLateralCacheAttributes extends LateralCacheAttributes implements Serializable

serialVersionUID: 1077889204513905220L

Serialized Fields

tcpServers

java.lang.String tcpServers

tcpServer

java.lang.String tcpServer

tcpListenerPort

int tcpListenerPort

udpDiscoveryAddr

java.lang.String udpDiscoveryAddr

udpDiscoveryPort

int udpDiscoveryPort

udpDiscoveryEnabled

boolean udpDiscoveryEnabled

allowPut

boolean allowPut

allowGet

boolean allowGet

issueRemoveOnPut

boolean issueRemoveOnPut

filterRemoveByHashCode

boolean filterRemoveByHashCode

Package org.apache.jcs.auxiliary.lateral.socket.tcp.behavior

Package org.apache.jcs.auxiliary.lateral.socket.tcp.discovery

Class org.apache.jcs.auxiliary.lateral.socket.tcp.discovery.UDPDiscoveryMessage extends java.lang.Object implements Serializable

serialVersionUID: -5332377899560951794L

Serialized Fields

messageType

int messageType

port

int port

host

java.lang.String host

requesterId

long requesterId
Description of the Field


cacheNames

java.util.ArrayList<E> cacheNames

Package org.apache.jcs.auxiliary.remote

Class org.apache.jcs.auxiliary.remote.RemoteCache extends java.lang.Object implements Serializable

serialVersionUID: -5329231850422826460L

Serialized Fields

cacheName

java.lang.String cacheName

irca

IRemoteCacheAttributes irca

remote

IRemoteCacheService remote

listener

IRemoteCacheListener listener

attr

IElementAttributes attr

pool

ThreadPool pool

usePoolForGet

boolean usePoolForGet

elementSerializer

IElementSerializer elementSerializer

Class org.apache.jcs.auxiliary.remote.RemoteCacheAttributes extends AbstractAuxiliaryCacheAttributes implements Serializable

serialVersionUID: -1555143736942374000L

Serialized Fields

remoteServiceName

java.lang.String remoteServiceName

remoteHost

java.lang.String remoteHost

remotePort

int remotePort

failoverServers

java.lang.String 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.


clusterServers

java.lang.String clusterServers

localPort

int localPort

remoteType

int remoteType

failoverIndex

int failoverIndex

failovers

java.lang.String[] failovers

removeUponRemotePut

boolean removeUponRemotePut

getOnly

boolean getOnly

localClusterConsistency

boolean localClusterConsistency

threadPoolName

java.lang.String threadPoolName

getTimeoutMillis

int getTimeoutMillis

rmiSocketFactoryTimeoutMillis

int rmiSocketFactoryTimeoutMillis

receive

boolean receive

zombieQueueMaxSize

int zombieQueueMaxSize

Class org.apache.jcs.auxiliary.remote.RemoteCacheListener extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

disposed

boolean disposed

irca

IRemoteCacheAttributes irca
The remote cache configuration object.


puts

int puts
Number of put requests received. For debugging only.


removes

int removes
Number of remove requests received. For debugging only.


listenerId

long listenerId
This is set by the remote cache server.

Class org.apache.jcs.auxiliary.remote.RemoteCacheListener_Stub extends java.rmi.server.RemoteStub implements Serializable

serialVersionUID: 2L

Class org.apache.jcs.auxiliary.remote.RemoteCacheManager extends java.lang.Object implements Serializable

serialVersionUID: 798077557166389498L

Serialized Fields

clients

int clients

caches

java.util.Map<K,V> caches

host

java.lang.String host

port

int port

service

java.lang.String service

irca

IRemoteCacheAttributes irca

remoteService

IRemoteCacheService remoteService
Handle to the remote cache service; or a zombie handle if failed to connect.


remoteWatch

RemoteCacheWatchRepairable remoteWatch
Wrapper of the remote cache watch service; or wrapper of a zombie service if failed to connect.


cacheMgr

ICompositeCacheManager cacheMgr
The cache manager listeners will need to use to get a cache.


registry

java.lang.String registry

Class org.apache.jcs.auxiliary.remote.RemoteCacheNoWait extends java.lang.Object implements Serializable

serialVersionUID: -3104089136003714717L

Serialized Fields

cache

IRemoteCacheClient cache

cacheEventQueue

ICacheEventQueue cacheEventQueue

getCount

int getCount

removeCount

int removeCount

putCount

int putCount

Class org.apache.jcs.auxiliary.remote.RemoteCacheNoWaitFacade extends java.lang.Object implements Serializable

serialVersionUID: -4529970797620747110L

Serialized Fields

noWaits

RemoteCacheNoWait[] noWaits
The connection to a remote server, or a zombie.


cacheName

java.lang.String cacheName

remoteCacheAttributes

RemoteCacheAttributes remoteCacheAttributes
holds failover and cluster information


cacheMgr

ICompositeCacheManager cacheMgr

Package org.apache.jcs.auxiliary.remote.behavior

Package org.apache.jcs.auxiliary.remote.server

Class org.apache.jcs.auxiliary.remote.server.RemoteCacheServer_Stub extends java.rmi.server.RemoteStub implements Serializable

serialVersionUID: 2L

Class org.apache.jcs.auxiliary.remote.server.RemoteCacheServerAttributes extends AbstractAuxiliaryCacheAttributes implements Serializable

serialVersionUID: -2741662082869155365L

Serialized Fields

remoteServiceName

java.lang.String remoteServiceName

remoteHost

java.lang.String remoteHost

remotePort

int remotePort

clusterServers

java.lang.String clusterServers
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.


servicePort

int servicePort

remoteType

int remoteType

removeUponRemotePut

boolean removeUponRemotePut

getOnly

boolean getOnly

localClusterConsistency

boolean localClusterConsistency

allowClusterGet

boolean allowClusterGet

configFileName

java.lang.String configFileName

Class org.apache.jcs.auxiliary.remote.server.RemoteCacheStartupServlet extends javax.servlet.http.HttpServlet implements Serializable

serialVersionUID: 1L


Package org.apache.jcs.auxiliary.remote.server.behavior

Package org.apache.jcs.config

Class org.apache.jcs.config.PropertySetterException extends java.lang.Exception implements Serializable

serialVersionUID: -210271658004609028L

Serialized Fields

rootCause

java.lang.Throwable rootCause
Description of the Field


Package org.apache.jcs.engine

Class org.apache.jcs.engine.CacheElement extends java.lang.Object implements Serializable

serialVersionUID: -6062305728297627263L

Serialized Fields

cacheName

java.lang.String cacheName
The name of the cache region. This is a namespace.


key

java.io.Serializable key
This is the cache key by which the value can be referenced.


val

java.io.Serializable val
This is the cached value, reference by the key.


attr

IElementAttributes attr
These attributes hold information about the element and what it is allowed to do.

Class org.apache.jcs.engine.CacheElementSerialized extends java.lang.Object implements Serializable

serialVersionUID: -7265084818647601874L

Serialized Fields

cacheName

java.lang.String cacheName
The name of the cache region. This is a namespace.


key

java.io.Serializable key
This is the cache key by which the value can be referenced.


serializedValue

byte[] serializedValue

elementAttributes

IElementAttributes elementAttributes
These attributes hold information about the element and what it is allowed to do.

Class org.apache.jcs.engine.CompositeCacheAttributes extends java.lang.Object implements Serializable

serialVersionUID: 6754049978134196787L

Serialized Fields

useLateral

boolean useLateral

useRemote

boolean useRemote

useDisk

boolean useDisk
Whether we should use a disk cache if it is configured.


useMemoryShrinker

boolean useMemoryShrinker
Whether or not we should run the memory shrinker thread.


maxObjs

int maxObjs
The maximum objects that the memory cache will be allowed to hold.


maxMemoryIdleTimeSeconds

long maxMemoryIdleTimeSeconds
maxMemoryIdleTimeSeconds


shrinkerIntervalSeconds

long shrinkerIntervalSeconds
shrinkerIntervalSeconds


maxSpoolPerRun

int maxSpoolPerRun
The maximum number the shrinker will spool to disk per run.


cacheName

java.lang.String cacheName
The name of this cache region.


memoryCacheName

java.lang.String memoryCacheName
The name of the memory cache implementation class.


diskUsagePattern

short diskUsagePattern

Class org.apache.jcs.engine.ElementAttributes extends java.lang.Object implements Serializable

serialVersionUID: 7814990748035017441L

Serialized Fields

IS_SPOOL

boolean IS_SPOOL
Can this item be flushed to disk


IS_LATERAL

boolean IS_LATERAL
Is this item laterally distributable


IS_REMOTE

boolean IS_REMOTE
Can this item be sent to the remote cache


IS_ETERNAL

boolean 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.


version

long version
The object version. This is currently not used.


maxLifeSeconds

long maxLifeSeconds
Max life seconds


maxIdleTimeSeconds

long maxIdleTimeSeconds
The maximum time an entry can be idle. Setting this to -1 causes the idle time check to be ignored.


size

int size
The byte size of the field. Must be manually set.


createTime

long createTime
The creation time. This is used to enforce the max life.


lastAccessTime

long lastAccessTime
The last access time. This is used to enforce the max idel time.


Package org.apache.jcs.engine.behavior

Package org.apache.jcs.engine.control

Class org.apache.jcs.engine.control.CompositeCache extends java.lang.Object implements Serializable

serialVersionUID: -2838097410378294960L

Serialized Fields

auxCaches

AuxiliaryCache[] auxCaches

alive

boolean alive

cacheName

java.lang.String cacheName

attr

IElementAttributes attr
Region Elemental Attributes, default.


cacheAttr

ICompositeCacheAttributes cacheAttr
Cache Attributes, for hub and memory auxiliary.


updateCount

int updateCount

removeCount

int removeCount

hitCountRam

int hitCountRam
Memory cache hit count


hitCountAux

int hitCountAux
Auxiliary cache hit count (number of times found in ANY auxiliary)


auxHitCountByIndex

int[] auxHitCountByIndex
Auxiliary hit counts broken down by auxiliary.


missCountNotFound

int missCountNotFound
Count of misses where element was not found.


missCountExpired

int missCountExpired
Count of misses where element was expired.


memCache

MemoryCache memCache
The cache hub can only have one memory cache. This could be made more flexible in the future, but they are tied closely together. More than one doesn't make much sense.

Class org.apache.jcs.engine.control.CompositeCacheManager extends java.lang.Object implements Serializable

serialVersionUID: 7598584393134401756L

Serialized Fields

caches

java.util.Hashtable<K,V> caches
Caches managed by this cache manager


systemCaches

java.util.Hashtable<K,V> systemCaches
Internal system caches for this cache manager


clients

int clients
Number of clients accessing this cache manager


defaultCacheAttr

ICompositeCacheAttributes defaultCacheAttr
Default cache attributes for this cache manager


defaultElementAttr

IElementAttributes defaultElementAttr
Default elemeent attributes for this cache manager


auxFacs

java.util.Hashtable<K,V> auxFacs
Used to keep track of configured auxiliaries


auxAttrs

java.util.Hashtable<K,V> auxAttrs
???


props

java.util.Properties props
Properties with which this manager was configured


defaultAuxValues

java.lang.String defaultAuxValues
The default auxiliary caches to be used if not preconfigured


shutdownObservers

java.util.Set<E> shutdownObservers

Package org.apache.jcs.engine.control.event

Class org.apache.jcs.engine.control.event.ElementEvent extends java.util.EventObject implements Serializable

serialVersionUID: -5364117411457467056L

Serialized Fields

elementEvent

int elementEvent

Package org.apache.jcs.engine.control.event.behavior

Package org.apache.jcs.engine.control.group

Class org.apache.jcs.engine.control.group.GroupAttrName extends java.lang.Object implements Serializable

serialVersionUID: 1586079686300744198L

Serialized Fields

groupId

GroupId groupId
Description of the Field


attrName

java.lang.Object attrName
the name of the attribute


toString

java.lang.String toString

Class org.apache.jcs.engine.control.group.GroupId extends java.lang.Object implements Serializable

serialVersionUID: 4626368486444860133L

Serialized Fields

groupName

java.lang.String groupName
Description of the Field


cacheName

java.lang.String cacheName
the name of the region.


toString

java.lang.String toString

Package org.apache.jcs.engine.memory

Class org.apache.jcs.engine.memory.AbstractMemoryCache extends java.lang.Object implements Serializable

Serialized Fields

cacheName

java.lang.String cacheName
The region name. This defines a namespace of sorts.


map

java.util.Map<K,V> map
Map where items are stored by key


attr

IElementAttributes attr
Region Elemental Attributes, used as a default.


cattr

ICompositeCacheAttributes cattr
Cache Attributes


cache

CompositeCache cache
The cache region this store is associated with


status

int status
status


chunkSize

int chunkSize
How many to spool at a time. TODO make configurable


Package org.apache.jcs.engine.memory.lru

Class org.apache.jcs.engine.memory.lru.LRUMemoryCache extends AbstractMemoryCache implements Serializable

serialVersionUID: 6403738094136424201L

Serialized Fields

list

DoubleLinkedList list
thread-safe double linked list for lru


hitCnt

int hitCnt
number of hits


missCnt

int missCnt
number of misses


putCnt

int putCnt
number of puts


Package org.apache.jcs.engine.memory.mru

Class org.apache.jcs.engine.memory.mru.MRUMemoryCache extends AbstractMemoryCache implements Serializable

serialVersionUID: 5013101678192336129L

Serialized Fields

hitCnt

int hitCnt

missCnt

int missCnt

putCnt

int putCnt

lockMe

int[] lockMe
Object to lock on the Field


mrulist

java.util.LinkedList<E> mrulist
MRU list.


Package org.apache.jcs.engine.memory.util

Class org.apache.jcs.engine.memory.util.MemoryElementDescriptor extends DoubleLinkedListNode implements Serializable

serialVersionUID: -1905161209035522460L

Serialized Fields

ce

ICacheElement ce
The CacheElement wrapped by this descriptor


Package org.apache.jcs.engine.stats

Class org.apache.jcs.engine.stats.CacheStats extends Stats implements Serializable

serialVersionUID: 529914708798168590L

Serialized Fields

regionName

java.lang.String regionName

auxStats

IStats[] auxStats

stats

IStatElement[] stats

Class org.apache.jcs.engine.stats.Stats extends java.lang.Object implements Serializable

serialVersionUID: 227327902875154010L

Serialized Fields

stats

IStatElement[] stats

typeName

java.lang.String typeName

Package org.apache.jcs.engine.stats.behavior

Package org.apache.jcs.utils.struct

Class org.apache.jcs.utils.struct.DoubleLinkedListNode extends java.lang.Object implements Serializable

serialVersionUID: -1114934407695836097L

Serialized Fields

payload

java.lang.Object payload

prev

DoubleLinkedListNode prev
Double Linked list references


next

DoubleLinkedListNode next
Double Linked list references

Class org.apache.jcs.utils.struct.LRUElementDescriptor extends DoubleLinkedListNode implements Serializable

serialVersionUID: 8249555756363020156L

Serialized Fields

key

java.lang.Object key
key

Class org.apache.jcs.utils.struct.LRUMapEntry extends java.lang.Object implements Serializable

serialVersionUID: -8176116317739129331L

Serialized Fields

key

java.lang.Object key

value

java.lang.Object value



Copyright © 2002-2007 Apache Software Foundation. All Rights Reserved.