Serialized Form
Package org.apache.jcs.access.exception |
Package org.apache.jcs.access.monitor |
cacheMgr
CompositeCacheManager cacheMgr
- Description of the Field
Package org.apache.jcs.admin.servlet |
Package org.apache.jcs.auxiliary |
cacheName
java.lang.String cacheName
name
java.lang.String name
eventQueueType
int eventQueueType
eventQueuePoolName
java.lang.String eventQueuePoolName
Package org.apache.jcs.auxiliary.disk |
dcattr
IDiskCacheAttributes dcattr
- Generic disk cache attributes
purgatory
java.util.Map 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
diskPath
java.lang.String diskPath
- path to disk
maxPurgatorySize
int maxPurgatorySize
- default to 5000
shutdownSpoolTimeLimit
int shutdownSpoolTimeLimit
spoolable
boolean spoolable
- Is the element ready to be spooled?
cacheElement
ICacheElement cacheElement
- Wrapped cache Element
Package org.apache.jcs.auxiliary.disk.hsql |
numInstances
int numInstances
isAlive
boolean isAlive
cattr
HSQLCacheAttributes cattr
cConn
java.sql.Connection cConn
sStatement
java.sql.Statement sStatement
diskPath
java.lang.String diskPath
Package org.apache.jcs.auxiliary.disk.indexed |
fileName
java.lang.String fileName
dataFile
IndexedDisk dataFile
keyFile
IndexedDisk keyFile
keyHash
java.util.Map keyHash
maxKeySize
int maxKeySize
rafDir
java.io.File rafDir
doRecycle
boolean doRecycle
isOptomizing
boolean isOptomizing
optimizingPutList
java.util.LinkedList optimizingPutList
recycle
SortedPreferentialArray recycle
cattr
IndexedDiskCacheAttributes cattr
optCnt
int optCnt
recycleCnt
int recycleCnt
storageLock
EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock storageLock
- use this lock to synchronize reads and writes to the underlying storage
mechansism.
timesOptimized
int timesOptimized
tag
java.lang.String tag
tag
tells us which map we are working on.
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
caches
java.util.Hashtable caches
defaultCacheAttributes
IndexedDiskCacheAttributes defaultCacheAttributes
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.jisp |
numInstances
int numInstances
isAlive
boolean isAlive
- Description of the Field
cattr
JISPCacheAttributes cattr
database
com.coyotegulch.jisp.IndexedObjectDatabase database
index1
com.coyotegulch.jisp.BTreeIndex index1
jispDataFileName
java.lang.String jispDataFileName
jispIndexFileName
java.lang.String jispIndexFileName
clearOnStart
boolean clearOnStart
readExternal
public void readExternal(java.io.ObjectInput in)
throws java.io.IOException,
java.lang.ClassNotFoundException
- Description of the Method
writeExternal
public void writeExternal(java.io.ObjectOutput out)
throws java.io.IOException
- Description of the Method
Package org.apache.jcs.auxiliary.javagroups |
log
org.apache.commons.logging.Log log
cacheName
java.lang.String cacheName
status
int status
getFromPeers
boolean getFromPeers
cache
CompositeCache cache
channel
org.jgroups.Channel channel
dispatcher
org.jgroups.blocks.MessageDispatcher dispatcher
channelFactoryClassName
java.lang.String channelFactoryClassName
channelProperties
java.lang.String channelProperties
getFromPeers
boolean getFromPeers
Package org.apache.jcs.auxiliary.lateral |
cattr
ILateralCacheAttributes cattr
cacheName
java.lang.String cacheName
lateral
ILateralCacheService lateral
- either http, socket.udp, or socket.tcp can set in config
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
tcpServers
java.lang.String tcpServers
tcpServer
java.lang.String tcpServer
tcpListenerPort
int tcpListenerPort
udpDiscoveryAddr
java.lang.String udpDiscoveryAddr
udpDiscoveryPort
int udpDiscoveryPort
udpDiscoveryEnabled
boolean udpDiscoveryEnabled
jgChannelProperties
java.lang.String jgChannelProperties
putOnlyMode
boolean putOnlyMode
receive
boolean receive
caches
java.util.Map caches
lca
ILateralCacheAttributes lca
- Description of the Field
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.
cache
LateralCache cache
q
ICacheEventQueue q
noWaits
LateralCacheNoWait[] noWaits
- Description of the Field
cacheName
java.lang.String cacheName
ce
ICacheElement ce
- Description of the Field
requesterId
long requesterId
- Description of the Field
command
int command
- Description of the Field
Package org.apache.jcs.auxiliary.lateral.javagroups |
receiver
LateralJGReceiver receiver
ilca
ILateralCacheAttributes ilca
inited
boolean inited
puts
int puts
Package org.apache.jcs.auxiliary.lateral.socket.tcp |
receiver
LateralTCPListener.ListenerThread receiver
- The socket listener
ilca
ILateralCacheAttributes ilca
port
int port
pooledExecutor
EDU.oswego.cs.dl.util.concurrent.PooledExecutor pooledExecutor
putCnt
int putCnt
removeCnt
int removeCnt
Package org.apache.jcs.auxiliary.lateral.socket.tcp.discovery |
messageType
int messageType
port
int port
host
java.lang.String host
requesterId
long requesterId
- Description of the Field
cacheNames
java.util.ArrayList cacheNames
Package org.apache.jcs.auxiliary.remote |
cacheName
java.lang.String cacheName
irca
IRemoteCacheAttributes irca
remote
IRemoteCacheService remote
listener
IRemoteCacheListener listener
attr
IElementAttributes attr
pool
ThreadPool pool
usePoolForGet
boolean usePoolForGet
remoteServiceName
java.lang.String remoteServiceName
remoteHost
java.lang.String remoteHost
remotePort
int remotePort
failoverServers
java.lang.String failoverServers
clusterServers
java.lang.String clusterServers
getFromCluster
boolean getFromCluster
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
irca
IRemoteCacheAttributes irca
- The remote cache configuration object.
puts
int puts
- Number of put requests received
removes
int removes
- Number of remove requests received
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
clients
int clients
caches
java.util.Map 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.
cache
RemoteCache cache
q
ICacheEventQueue q
noWaits
RemoteCacheNoWait[] noWaits
- The connection to a remote server, or a zombie.
cacheName
java.lang.String cacheName
rca
RemoteCacheAttributes rca
Package org.apache.jcs.auxiliary.remote.server |
className
java.lang.String className
- Description of the Field
puts
int puts
cacheListenersMap
java.util.Hashtable cacheListenersMap
clusterListenersMap
java.util.Hashtable clusterListenersMap
cacheManager
CompositeCacheManager cacheManager
idTypeMap
java.util.Hashtable idTypeMap
listenerId
int[] listenerId
rcsa
IRemoteCacheServerAttributes rcsa
- Description of the Field
Class org.apache.jcs.auxiliary.remote.server.RemoteCacheServer_Stub extends java.rmi.server.RemoteStub implements Serializable |
serialVersionUID: 2l
remoteServiceName
java.lang.String remoteServiceName
remoteHost
java.lang.String remoteHost
remotePort
int remotePort
clusterServers
java.lang.String clusterServers
getFromCluster
boolean getFromCluster
servicePort
int servicePort
remoteType
int remoteType
removeUponRemotePut
boolean removeUponRemotePut
getOnly
boolean getOnly
localClusterConsistency
boolean localClusterConsistency
allowClusterGet
boolean allowClusterGet
configFileName
java.lang.String configFileName
irca
IRemoteCacheAttributes irca
- Description of the Field
puts
int puts
- Description of the Field
removes
int removes
Class org.apache.jcs.auxiliary.remote.server.RemoteCacheServerListener_Stub extends java.rmi.server.RemoteStub implements Serializable |
serialVersionUID: 2l
Package org.apache.jcs.config |
rootCause
java.lang.Throwable rootCause
- Description of the Field
Package org.apache.jcs.engine |
IS_DISTRIBUTE
boolean IS_DISTRIBUTE
- Description of the Field
IS_LATERAL
boolean IS_LATERAL
- Description of the Field
IS_NOFLUSH
boolean IS_NOFLUSH
- Description of the Field
IS_REPLY
boolean IS_REPLY
- Description of the Field
IS_SYNCHRONIZE
boolean IS_SYNCHRONIZE
- Description of the Field
IS_SPOOL
boolean IS_SPOOL
- Description of the Field
IS_GROUP_TTL_DESTROY
boolean IS_GROUP_TTL_DESTROY
- Description of the Field
IS_ORIGINAL
boolean IS_ORIGINAL
- Description of the Field
IS_REMOTE
boolean IS_REMOTE
- Description of the Field
IS_ETERNAL
boolean IS_ETERNAL
- Description of the Field
version
long version
- Description of the Field
ttl
long ttl
- Description of the Field
default_ttl
long default_ttl
- Description of the Field
idle
long idle
- Description of the Field
lastAccess
long lastAccess
- Description of the Field
size
int size
- Description of the Field
createTime
long createTime
- Description of the Field
cacheName
java.lang.String cacheName
- Description of the Field
key
java.io.Serializable key
- Description of the Field
val
java.io.Serializable val
- Description of the Field
attr
ElementAttributes attr
- Description of the Field
useLateral
boolean useLateral
useRemote
boolean useRemote
useDisk
boolean useDisk
useMemoryShrinker
boolean useMemoryShrinker
maxObjs
int maxObjs
maxMemoryIdleTimeSeconds
long maxMemoryIdleTimeSeconds
- maxMemoryIdleTimeSeconds
shrinkerIntervalSeconds
long shrinkerIntervalSeconds
- shrinkerIntervalSeconds
maxSpoolPerRun
int maxSpoolPerRun
cacheName
java.lang.String cacheName
memoryCacheName
java.lang.String memoryCacheName
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
- can turn off expiration
version
long version
- Description of the Field
mls
long mls
- Max life seconds
idle
long idle
- Description of the Field
size
int size
- The byte size of teh field. Must be manually set.
createTime
long createTime
- The creation time
lastAccessTime
long lastAccessTime
- The last access time
Package org.apache.jcs.engine.control |
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
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.
caches
java.util.Hashtable caches
- Caches managed by this cache manager
systemCaches
java.util.Hashtable 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 auxFacs
- Used to keep track of configured auxiliaries
auxAttrs
java.util.Hashtable 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
Package org.apache.jcs.engine.control.event |
elementEvent
int elementEvent
Package org.apache.jcs.engine.control.group |
groupId
GroupId groupId
- Description of the Field
attrName
java.lang.Object attrName
toString
java.lang.String toString
groupName
java.lang.String groupName
- Description of the Field
cacheName
java.lang.String cacheName
toString
java.lang.String toString
Package org.apache.jcs.engine.memory |
cacheName
java.lang.String cacheName
map
java.util.Map 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
chunkSize
int chunkSize
Package org.apache.jcs.engine.memory.lru |
list
DoubleLinkedList list
hitCnt
int hitCnt
missCnt
int missCnt
putCnt
int putCnt
Package org.apache.jcs.engine.memory.mru |
hitCnt
int hitCnt
missCnt
int missCnt
putCnt
int putCnt
lockMe
int[] lockMe
- Object to lock on the Field
mrulist
java.util.LinkedList mrulist
- MRU list.
Package org.apache.jcs.engine.memory.util |
payload
java.lang.Object payload
prev
DoubleLinkedListNode prev
- Double Linked list references
next
DoubleLinkedListNode next
- Double Linked list references
ce
ICacheElement ce
- The CacheElement wrapped by this descriptor
Package org.apache.jcs.engine.stats |
regionName
java.lang.String regionName
auxStats
IStats[] auxStats
stats
IStatElement[] stats
stats
IStatElement[] stats
typeName
java.lang.String typeName
Package org.apache.jcs.utils.data |
props
java.util.Properties props
fileName
java.lang.String fileName
simpleKeys
int simpleKeys
compoundKeys
int compoundKeys
Package org.apache.jcs.utils.struct |
key
java.lang.Object key
key
Copyright © 2002-2005 Apache Software Foundation. All Rights Reserved.