Serialized Form


Package org.infinispan

Class org.infinispan.CacheException extends RuntimeException implements Serializable

serialVersionUID: -4386393072593859164L


Package org.infinispan.client.hotrod.exceptions

Class org.infinispan.client.hotrod.exceptions.HotRodClientException extends RuntimeException implements Serializable

Serialized Fields

messageId

long messageId

errorStatusCode

int errorStatusCode

Class org.infinispan.client.hotrod.exceptions.HotRodTimeoutException extends HotRodClientException implements Serializable

Class org.infinispan.client.hotrod.exceptions.InvalidResponseException extends HotRodClientException implements Serializable

Class org.infinispan.client.hotrod.exceptions.RemoteCacheManagerNotStartedException extends HotRodClientException implements Serializable

Class org.infinispan.client.hotrod.exceptions.TransportException extends HotRodClientException implements Serializable


Package org.infinispan.config

Class org.infinispan.config.AbstractConfigurationBean extends Object implements Serializable

serialVersionUID: 4879873994727821938L

Serialized Fields

accessible

boolean accessible

overriddenConfigurationElements

Set<E> overriddenConfigurationElements

Class org.infinispan.config.AbstractNamedCacheConfigurationBean extends AbstractConfigurationBean implements Serializable

serialVersionUID: -3838074220419703543L

Serialized Fields

cr

ComponentRegistry cr

Class org.infinispan.config.CacheLoaderManagerConfig extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 2210349340378984424L

Serialized Fields

passivation

Boolean passivation

preload

Boolean preload

shared

Boolean shared

cacheLoaderConfigs

List<E> cacheLoaderConfigs

Class org.infinispan.config.Configuration extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 5553791890144997466L

Serialized Fields

globalConfiguration

GlobalConfiguration globalConfiguration

name

String name

locking

Configuration.LockingType locking

loaders

CacheLoaderManagerConfig loaders

transaction

Configuration.TransactionType transaction

customInterceptors

Configuration.CustomInterceptorsType customInterceptors

eviction

Configuration.EvictionType eviction

expiration

Configuration.ExpirationType expiration

unsafe

Configuration.UnsafeType unsafe

clustering

Configuration.ClusteringType clustering

jmxStatistics

Configuration.JmxStatistics jmxStatistics

lazyDeserialization

Configuration.LazyDeserialization lazyDeserialization

invocationBatching

Configuration.InvocationBatching invocationBatching

deadlockDetection

Configuration.DeadlockDetectionType deadlockDetection

indexing

Configuration.QueryConfigurationBean indexing

Class org.infinispan.config.Configuration.AsyncType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: -7726319188826197399L

Serialized Fields

readFromXml

boolean readFromXml

useReplQueue

Boolean useReplQueue

replQueueMaxElements

Integer replQueueMaxElements

replQueueInterval

Long replQueueInterval

asyncMarshalling

Boolean asyncMarshalling

replQueueClass

String replQueueClass

unmarshalledFromXml

boolean unmarshalledFromXml

Class org.infinispan.config.Configuration.BooleanAttributeType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 2296863404153834686L

Serialized Fields

fieldName

String fieldName

enabled

Boolean enabled

Class org.infinispan.config.Configuration.ClusteringType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 4048135465543498430L

Serialized Fields

stringMode

String stringMode

mode

Configuration.CacheMode mode

sync

Configuration.SyncType sync

stateRetrieval

Configuration.StateRetrievalType stateRetrieval

l1

Configuration.L1Type l1

async

Configuration.AsyncType async

hash

Configuration.HashType hash

Class org.infinispan.config.Configuration.CustomInterceptorsType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 7187545782011884661L

Serialized Fields

customInterceptors

List<E> customInterceptors

Class org.infinispan.config.Configuration.DeadlockDetectionType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: -7178286048602531152L

Serialized Fields

enabled

Boolean enabled

spinDuration

Long spinDuration

Class org.infinispan.config.Configuration.EvictionType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: -1248563712058858791L

Serialized Fields

wakeUpInterval

Long wakeUpInterval

strategy

EvictionStrategy strategy

maxEntries

Integer maxEntries

threadPolicy

EvictionThreadPolicy threadPolicy

Class org.infinispan.config.Configuration.ExpirationType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 5757161438110848530L

Serialized Fields

lifespan

Long lifespan

maxIdle

Long maxIdle

Class org.infinispan.config.Configuration.HashType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 752218766840948822L

Serialized Fields

consistentHashClass

String consistentHashClass

hashFunctionClass

String hashFunctionClass

numOwners

Integer numOwners

rehashWait

Long rehashWait

rehashRpcTimeout

Long rehashRpcTimeout

rehashEnabled

Boolean rehashEnabled

Class org.infinispan.config.Configuration.InvocationBatching extends Configuration.BooleanAttributeType implements Serializable

serialVersionUID: 5854115656815587815L

Class org.infinispan.config.Configuration.JmxStatistics extends Configuration.BooleanAttributeType implements Serializable

serialVersionUID: 8716456707015486673L

Class org.infinispan.config.Configuration.L1Type extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: -4703587764861110638L

Serialized Fields

enabled

Boolean enabled

lifespan

Long lifespan

onRehash

Boolean onRehash

Class org.infinispan.config.Configuration.LazyDeserialization extends Configuration.BooleanAttributeType implements Serializable

serialVersionUID: 7404820498857564962L

Class org.infinispan.config.Configuration.LockingType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 8142143187082119506L

Serialized Fields

lockAcquisitionTimeout

Long lockAcquisitionTimeout

isolationLevel

IsolationLevel isolationLevel

writeSkewCheck

Boolean writeSkewCheck

useLockStriping

Boolean useLockStriping

concurrencyLevel

Integer concurrencyLevel

Class org.infinispan.config.Configuration.QueryConfigurationBean extends AbstractConfigurationBean implements Serializable

serialVersionUID: 2891683014353342549L

Serialized Fields

enabled

Boolean enabled

indexLocalOnly

Boolean indexLocalOnly

Class org.infinispan.config.Configuration.StateRetrievalType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 3709234918426217096L

Serialized Fields

fetchInMemoryState

Boolean fetchInMemoryState

alwaysProvideInMemoryState

Boolean alwaysProvideInMemoryState

timeout

Long timeout

initialRetryWaitTime

Long initialRetryWaitTime

retryWaitTimeIncreaseFactor

Integer retryWaitTimeIncreaseFactor

numRetries

Integer numRetries

logFlushTimeout

Long logFlushTimeout

maxNonProgressingLogWrites

Integer maxNonProgressingLogWrites

Class org.infinispan.config.Configuration.SyncType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 8419216253674289524L

Serialized Fields

replTimeout

Long replTimeout

unmarshalledFromXml

boolean unmarshalledFromXml

Class org.infinispan.config.Configuration.TransactionType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: -3867090839830874603L

Serialized Fields

transactionManagerLookupClass

String transactionManagerLookupClass

transactionManagerLookup

TransactionManagerLookup transactionManagerLookup

syncCommitPhase

Boolean syncCommitPhase

syncRollbackPhase

Boolean syncRollbackPhase

useEagerLocking

Boolean useEagerLocking

eagerLockSingleNode

Boolean eagerLockSingleNode

cacheStopTimeout

Integer cacheStopTimeout

Class org.infinispan.config.Configuration.UnsafeType extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: -9200921443651234163L

Serialized Fields

unreliableReturnValues

Boolean unreliableReturnValues

Class org.infinispan.config.ConfigurationException extends CacheException implements Serializable

serialVersionUID: -5576382839360927955L

Serialized Fields

erroneousAttributes

List<E> erroneousAttributes

Class org.infinispan.config.CustomInterceptorConfig extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 6206233611032238190L

Serialized Fields

interceptor

CommandInterceptor interceptor

isFirst

boolean isFirst

isLast

boolean isLast

index

Integer index

after

String after

before

String before

position

org.infinispan.config.CustomInterceptorConfig.Position position

className

String className

properties

TypedProperties properties

Class org.infinispan.config.DuplicateCacheNameException extends ConfigurationException implements Serializable

serialVersionUID: 3829520782638366878L

Class org.infinispan.config.GlobalConfiguration extends AbstractConfigurationBean implements Serializable

serialVersionUID: 8910865501990177720L

Serialized Fields

asyncListenerExecutor

GlobalConfiguration.ExecutorFactoryType asyncListenerExecutor

asyncTransportExecutor

GlobalConfiguration.ExecutorFactoryType asyncTransportExecutor

evictionScheduledExecutor

GlobalConfiguration.ScheduledExecutorFactoryType evictionScheduledExecutor

replicationQueueScheduledExecutor

GlobalConfiguration.ScheduledExecutorFactoryType replicationQueueScheduledExecutor

globalJmxStatistics

GlobalConfiguration.GlobalJmxStatisticsType globalJmxStatistics

transport

GlobalConfiguration.TransportType transport

serialization

GlobalConfiguration.SerializationType serialization

shutdown

GlobalConfiguration.ShutdownType shutdown

gcr

GlobalComponentRegistry gcr

Class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType extends GlobalConfiguration.FactoryClassWithPropertiesType implements Serializable

serialVersionUID: 6895901500645539386L

Serialized Fields

factory

String factory

Class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType extends org.infinispan.config.AbstractConfigurationBeanWithGCR implements Serializable

serialVersionUID: 7625606997888180254L

Serialized Fields

properties

TypedProperties properties

Class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType extends org.infinispan.config.AbstractConfigurationBeanWithGCR implements Serializable

serialVersionUID: 6639689526822921024L

Serialized Fields

enabled

Boolean enabled

jmxDomain

String jmxDomain

mBeanServerLookup

String mBeanServerLookup

allowDuplicateDomains

Boolean allowDuplicateDomains

cacheManagerName

String cacheManagerName

properties

TypedProperties properties

mBeanServerLookupInstance

MBeanServerLookup mBeanServerLookupInstance

Class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType extends GlobalConfiguration.FactoryClassWithPropertiesType implements Serializable

serialVersionUID: 7806391452092647488L

Serialized Fields

factory

String factory

Class org.infinispan.config.GlobalConfiguration.SerializationType extends org.infinispan.config.AbstractConfigurationBeanWithGCR implements Serializable

serialVersionUID: -925947118621507282L

Serialized Fields

marshallerClass

String marshallerClass

version

String version

Class org.infinispan.config.GlobalConfiguration.ShutdownType extends org.infinispan.config.AbstractConfigurationBeanWithGCR implements Serializable

serialVersionUID: 3427920991221031456L

Serialized Fields

hookBehavior

GlobalConfiguration.ShutdownHookBehavior hookBehavior

Class org.infinispan.config.GlobalConfiguration.TransportType extends org.infinispan.config.AbstractConfigurationBeanWithGCR implements Serializable

serialVersionUID: -4739815717370060368L

Serialized Fields

clusterName

String clusterName

machineId

String machineId

rackId

String rackId

siteId

String siteId

strictPeerToPeer

Boolean strictPeerToPeer

distributedSyncTimeout

Long distributedSyncTimeout

transportClass

String transportClass

nodeName

String nodeName

properties

TypedProperties properties

Package org.infinispan.demo

Class org.infinispan.demo.InfinispanDemo.AlternateColorTable extends JTable implements Serializable

Serialized Fields

c1

Color c1

c2

Color c2

Class org.infinispan.demo.InfinispanDemo.CachedDataTableModel extends AbstractTableModel implements Serializable

serialVersionUID: -7109980678271415778L

Serialized Fields

data

List<E> data

Class org.infinispan.demo.InfinispanDemo.ClusterTableModel extends AbstractTableModel implements Serializable

serialVersionUID: -4321027648450429007L

Serialized Fields

members

List<E> members

memberStates

List<E> memberStates

Package org.infinispan.demos.gridfs

Class org.infinispan.demos.gridfs.CacheManagerHolder extends HttpServlet implements Serializable


Package org.infinispan.ec2demo

Class org.infinispan.ec2demo.Influenza_N_P_CR_Element extends Object implements Serializable

serialVersionUID: -8703474569822388524L

Serialized Fields

ganNucleoid

String ganNucleoid

proteinMap

Map<K,V> proteinMap

Class org.infinispan.ec2demo.Nucleotide_Protein_Element extends Object implements Serializable

serialVersionUID: 2870569691958410447L

Serialized Fields

GenbankAccessionNumber

String GenbankAccessionNumber

Host

String Host

SubType

String SubType

country

String country

GenomeSequenceNumber

String GenomeSequenceNumber

YearFound

int YearFound

SequenceLength

int SequenceLength

VirusName

String VirusName

HostAge

String HostAge

HostGender

String HostGender

FullLengthSequence

Boolean FullLengthSequence

Package org.infinispan.ec2demo.web

Class org.infinispan.ec2demo.web.CacheSearchServlet extends HttpServlet implements Serializable

serialVersionUID: 1L

Serialized Fields

influenzaCache

Cache<K,V> influenzaCache

proteinCache

Cache<K,V> proteinCache

nucleiodCache

Cache<K,V> nucleiodCache

Package org.infinispan.io

Class org.infinispan.io.GridFile extends File implements Serializable

serialVersionUID: -6729548421029004260L

Serialized Fields

metadataCache

AdvancedCache<K,V> metadataCache

fs

GridFilesystem fs

name

String name

chunk_size

int chunk_size

Class org.infinispan.io.GridFile.Metadata extends Object implements Serializable

Serialization Methods

readExternal

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

writeExternal

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

Package org.infinispan.jmx

Class org.infinispan.jmx.JmxDomainConflictException extends CacheException implements Serializable

serialVersionUID: 8057798477119623578L


Package org.infinispan.loaders

Class org.infinispan.loaders.AbstractCacheLoaderConfig extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: -4303705423800914433L

Serialized Fields

cacheLoaderClassName

String cacheLoaderClassName

properties

TypedProperties properties

Class org.infinispan.loaders.AbstractCacheStoreConfig extends AbstractCacheLoaderConfig implements Serializable

serialVersionUID: 4607371052771122893L

Serialized Fields

ignoreModifications

Boolean ignoreModifications

fetchPersistentState

Boolean fetchPersistentState

purgeOnStartup

Boolean purgeOnStartup

purgeSynchronously

Boolean purgeSynchronously

purgerThreads

Integer purgerThreads

singletonStore

SingletonStoreConfig singletonStore

async

AsyncStoreConfig async

Class org.infinispan.loaders.CacheLoaderException extends Exception implements Serializable

serialVersionUID: -7640401612614646818L

Class org.infinispan.loaders.LockSupportCacheStoreConfig extends AbstractCacheStoreConfig implements Serializable

serialVersionUID: 842757200078048889L

Serialized Fields

lockConcurrencyLevel

int lockConcurrencyLevel

lockAcquistionTimeout

long lockAcquistionTimeout

Package org.infinispan.loaders.bdbje

Class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig extends AbstractCacheStoreConfig implements Serializable

serialVersionUID: -2913308899139287416L

Serialized Fields

location

String location

lockAcquistionTimeout

long lockAcquistionTimeout

maxTxRetries

int maxTxRetries

cacheDbNamePrefix

String cacheDbNamePrefix

catalogDbName

String catalogDbName

expiryDbPrefix

String expiryDbPrefix

cacheName

String cacheName

environmentPropertiesFile

String environmentPropertiesFile

Package org.infinispan.loaders.cassandra

Class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig extends LockSupportCacheStoreConfig implements Serializable

Serialized Fields

keySpace

String keySpace

entryColumnFamily

String entryColumnFamily

expirationColumnFamily

String expirationColumnFamily

sharedKeyspace

boolean sharedKeyspace

readConsistencyLevel

String readConsistencyLevel

writeConsistencyLevel

String writeConsistencyLevel

configurationPropertiesFile

String configurationPropertiesFile

keyMapper

String keyMapper

poolProperties

net.dataforte.cassandra.pool.PoolProperties poolProperties

Package org.infinispan.loaders.cloud

Class org.infinispan.loaders.cloud.CloudCacheStoreConfig extends LockSupportCacheStoreConfig implements Serializable

serialVersionUID: -9011054600279256849L

Serialized Fields

identity

String identity

password

String password

bucketPrefix

String bucketPrefix

proxyHost

String proxyHost

proxyPort

String proxyPort

requestTimeout

long requestTimeout

lazyPurgingOnly

boolean lazyPurgingOnly

cloudService

String cloudService

maxConnections

int maxConnections

secure

boolean secure

compress

boolean compress

cloudServiceLocation

String cloudServiceLocation

Package org.infinispan.loaders.cluster

Class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig extends AbstractCacheLoaderConfig implements Serializable

serialVersionUID: -44748358960849539L

Serialized Fields

remoteCallTimeout

long remoteCallTimeout

Package org.infinispan.loaders.decorators

Class org.infinispan.loaders.decorators.AsyncStoreConfig extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: -8596800049019004961L

Serialized Fields

enabled

Boolean enabled

threadPoolSize

Integer threadPoolSize

flushLockTimeout

Long flushLockTimeout

shutdownTimeout

Long shutdownTimeout

Class org.infinispan.loaders.decorators.SingletonStore.PushStateException extends Exception implements Serializable

serialVersionUID: 5542893943730200886L

Class org.infinispan.loaders.decorators.SingletonStoreConfig extends AbstractNamedCacheConfigurationBean implements Serializable

serialVersionUID: 824251894176131850L

Serialized Fields

enabled

Boolean enabled

pushStateWhenCoordinator

Boolean pushStateWhenCoordinator

pushStateTimeout

Long pushStateTimeout

Package org.infinispan.loaders.file

Class org.infinispan.loaders.file.FileCacheStoreConfig extends LockSupportCacheStoreConfig implements Serializable

serialVersionUID: 1551092386868095926L

Serialized Fields

location

String location

streamBufferSize

int streamBufferSize

Package org.infinispan.loaders.jdbc

Class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig extends LockSupportCacheStoreConfig implements Serializable

Serialized Fields

connectionFactoryConfig

ConnectionFactoryConfig connectionFactoryConfig

Class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig extends AbstractJdbcCacheStoreConfig implements Serializable

serialVersionUID: 842757200078048889L

Serialized Fields

lockConcurrencyLevel

int lockConcurrencyLevel

lockAcquistionTimeout

long lockAcquistionTimeout

tableManipulation

TableManipulation tableManipulation

manageConnectionFactory

boolean manageConnectionFactory

Package org.infinispan.loaders.jdbc.binary

Class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig extends AbstractNonDelegatingJdbcCacheStoreConfig implements Serializable

serialVersionUID: 7659899424935453635L


Package org.infinispan.loaders.jdbc.mixed

Class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig extends AbstractJdbcCacheStoreConfig implements Serializable

serialVersionUID: -1343548133363285687L

Serialized Fields

binaryTableManipulation

TableManipulation binaryTableManipulation

stringsTableManipulation

TableManipulation stringsTableManipulation

key2StringMapper

String key2StringMapper

binaryConcurrencyLevel

int binaryConcurrencyLevel

stringsConcurrencyLevel

int stringsConcurrencyLevel

lockAcquistionTimeout

int lockAcquistionTimeout

Package org.infinispan.loaders.jdbc.stringbased

Class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig extends AbstractNonDelegatingJdbcCacheStoreConfig implements Serializable

serialVersionUID: 8835350707132331983L

Serialized Fields

key2StringMapper

Key2StringMapper key2StringMapper

Package org.infinispan.loaders.jdbm

Class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig extends LockSupportCacheStoreConfig implements Serializable

serialVersionUID: -3686035269816837880L

Serialized Fields

location

String location

comparatorClassName

String comparatorClassName

expiryQueueSize

int expiryQueueSize

Class org.infinispan.loaders.jdbm.JdbmSerializer extends Object implements Serializable

Class org.infinispan.loaders.jdbm.NaturalComparator extends Object implements Serializable

serialVersionUID: 1L


Package org.infinispan.loaders.keymappers

Class org.infinispan.loaders.keymappers.UnsupportedKeyTypeException extends CacheLoaderException implements Serializable

serialVersionUID: 1442739860198872706L


Package org.infinispan.loaders.remote

Class org.infinispan.loaders.remote.RemoteCacheStoreConfig extends AbstractCacheStoreConfig implements Serializable

Serialized Fields

remoteCacheName

String remoteCacheName

hotRodClientProperties

Properties hotRodClientProperties

Package org.infinispan.lucene

Class org.infinispan.lucene.ChunkCacheKey extends Object implements Serializable

serialVersionUID: 4429712073623290126L

Serialized Fields

chunkId

int chunkId

indexName

String indexName

fileName

String fileName

hashCode

int hashCode

Class org.infinispan.lucene.FileCacheKey extends Object implements Serializable

serialVersionUID: -228474937509042691L

Serialized Fields

indexName

String indexName

fileName

String fileName

hashCode

int hashCode

Class org.infinispan.lucene.FileListCacheKey extends Object implements Serializable

serialVersionUID: 8965108175527988255L

Serialized Fields

indexName

String indexName

hashCode

int hashCode

Class org.infinispan.lucene.FileMetadata extends Object implements Serializable

serialVersionUID: -7150923427362644166L

Serialized Fields

lastModified

long lastModified

size

long size

bufferSize

int bufferSize

Class org.infinispan.lucene.FileReadLockKey extends Object implements Serializable

serialVersionUID: 7789410500198851940L

Serialized Fields

indexName

String indexName

fileName

String fileName

hashCode

int hashCode

Package org.infinispan.manager

Class org.infinispan.manager.NamedCacheNotFoundException extends Exception implements Serializable

serialVersionUID: 5937213470732655993L


Package org.infinispan.marshall

Class org.infinispan.marshall.NotSerializableException extends CacheException implements Serializable

serialVersionUID: 8217398736102723887L


Package org.infinispan.notifications

Class org.infinispan.notifications.IncorrectListenerException extends CacheException implements Serializable

serialVersionUID: 3847404572671886703L


Package org.infinispan.remoting

Class org.infinispan.remoting.MIMECacheEntry extends Object implements Serializable

serialVersionUID: -7857224258673285445L

Serialized Fields

contentType

String contentType
The MIME Content type value, for example application/octet-stream. Often used in HTTP headers.


data

byte[] data
The payload. The actual form of the contents depends on the contentType field. Will be String data if the contentType is application/json, application/xml or text/*


lastModified

long lastModified
The date the entry was created...

Class org.infinispan.remoting.RpcException extends CacheException implements Serializable

serialVersionUID: 33172388691879866L


Package org.infinispan.remoting.transport.jgroups

Class org.infinispan.remoting.transport.jgroups.SuspectException extends CacheException implements Serializable

serialVersionUID: -2965599037371850141L


Package org.infinispan.statetransfer

Class org.infinispan.statetransfer.StateTransferException extends Exception implements Serializable

serialVersionUID: -7679740750970789100L


Package org.infinispan.transaction.tm

Class org.infinispan.transaction.tm.BatchModeTransactionManager extends DummyBaseTransactionManager implements Serializable

serialVersionUID: 5656602677430350961L

Class org.infinispan.transaction.tm.DummyBaseTransactionManager extends Object implements Serializable

serialVersionUID: -6716097342564237376L

Class org.infinispan.transaction.tm.DummyTransactionManager extends DummyBaseTransactionManager implements Serializable

serialVersionUID: 4396695354693176535L

Class org.infinispan.transaction.tm.DummyUserTransaction extends Object implements Serializable

serialVersionUID: -6568400755677046127L

Serialized Fields

tm

DummyTransactionManager tm

l

List<E> l
List


Package org.infinispan.transaction.xa

Class org.infinispan.transaction.xa.InvalidTransactionException extends CacheException implements Serializable


Package org.infinispan.tree

Class org.infinispan.tree.FqnComparator extends Object implements Serializable

serialVersionUID: -1357631755443829281L

Class org.infinispan.tree.NodeNotExistsException extends CacheException implements Serializable

serialVersionUID: 779376138690777440L

Class org.infinispan.tree.NodeNotValidException extends CacheException implements Serializable

serialVersionUID: 6576866180835456994L


Package org.infinispan.util

Class org.infinispan.util.ByteArrayKey extends Object implements Serializable

Serialized Fields

data

byte[] data

Class org.infinispan.util.FastCopyHashMap extends AbstractMap<K,V> implements Serializable

serialVersionUID: 10929568968762L

Serialization Methods

readObject

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

writeObject

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

loadFactor

float loadFactor
The user defined load factor which defines when to resize

Class org.infinispan.util.ImmutableListCopy extends AbstractList<E> implements Serializable

serialVersionUID: 10929568968966L

Serialization Methods

readExternal

public void readExternal(ObjectInput in)
                  throws IOException,
                         ClassNotFoundException
See ImmutableListCopy.writeExternal(java.io.ObjectOutput) for serialization format

Throws:
IOException
ClassNotFoundException

writeExternal

public void writeExternal(ObjectOutput out)
                   throws IOException
Format: - entry array size (int) - elements (Object)

Throws:
IOException

Class org.infinispan.util.LegacyKeySupportTypedProperties extends TypedProperties implements Serializable

Serialized Fields

legacyKeyMapping

Map<K,V> legacyKeyMapping

Class org.infinispan.util.ModuleProperties extends Properties implements Serializable

serialVersionUID: 2558131508076199744L

Class org.infinispan.util.SimpleImmutableEntry extends Object implements Serializable

serialVersionUID: -6092752114794052323L

Serialized Fields

key

Object key

value

Object value

Class org.infinispan.util.TypedProperties extends Properties implements Serializable

serialVersionUID: 3799321248100686287L


Package org.infinispan.util.concurrent

Class org.infinispan.util.concurrent.BoundedConcurrentHashMap extends AbstractMap<K,V> implements Serializable

serialVersionUID: 7249069246763182397L

Serialization Methods

readObject

private void readObject(ObjectInputStream s)
                 throws IOException,
                        ClassNotFoundException
Reconstitute the ConcurrentHashMap instance from a stream (i.e., deserialize it).

Throws:
IOException
ClassNotFoundException

writeObject

private void writeObject(ObjectOutputStream s)
                  throws IOException
Save the state of the ConcurrentHashMap instance to a stream (i.e., serialize it).

Serial Data:
the key (Object) and value (Object) for each key-value mapping, followed by a null pair. The key-value mappings are emitted in no particular order.
Throws:
IOException
Serialized Fields

segmentMask

int segmentMask
Mask value for indexing into segments. The upper bits of a key's hash code are used to choose the segment.


segmentShift

int segmentShift
Shift value for indexing within segments.


segments

org.infinispan.util.concurrent.BoundedConcurrentHashMap.Segment<K,V>[] segments
The segments, each of which is a specialized hash table

Class org.infinispan.util.concurrent.ConcurrentHashSet extends AbstractSet<E> implements Serializable

serialVersionUID: 5312604953511379869L

Serialized Fields

map

ConcurrentHashMap<K,V> map

Class org.infinispan.util.concurrent.ReclosableLatch extends AbstractQueuedSynchronizer implements Serializable

serialVersionUID: 1744280161777661090L

Class org.infinispan.util.concurrent.TimeoutException extends CacheException implements Serializable

serialVersionUID: -8096787619908687038L


Package org.infinispan.util.concurrent.locks

Class org.infinispan.util.concurrent.locks.DeadlockDetectedException extends CacheException implements Serializable

serialVersionUID: -8529876192715526744L

Class org.infinispan.util.concurrent.locks.OwnableReentrantLock extends AbstractQueuedSynchronizer implements Serializable

serialVersionUID: 4932974734462848792L

Serialization Methods

readObject

private void readObject(ObjectInputStream s)
                 throws IOException,
                        ClassNotFoundException
Reconstitute this lock instance from a stream, resetting the lock to an unlocked state.

Throws:
IOException
ClassNotFoundException



Copyright © 2011 JBoss, a division of Red Hat. All Rights Reserved.