Serialized Form


Package com.hazelcast.cache

Class com.hazelcast.cache.CacheNotExistsException extends IllegalStateException implements Serializable

Class com.hazelcast.cache.HazelcastExpiryPolicy extends Object implements Serializable

Serialized Fields

create

javax.cache.expiry.Duration create

access

javax.cache.expiry.Duration access

update

javax.cache.expiry.Duration update

Package com.hazelcast.cache.impl

Class com.hazelcast.cache.impl.CacheClearResponse extends Object implements Serializable

Serialized Fields

response

Object response

Class com.hazelcast.cache.impl.CacheEntryEventImpl extends javax.cache.event.CacheEntryEvent<K,V> implements Serializable

Serialized Fields

key

Object key

newValue

Object newValue

oldValue

Object oldValue

Class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl extends Object implements Serializable

serialVersionUID: -1L


Package com.hazelcast.cache.impl.record

Class com.hazelcast.cache.impl.record.CacheRecordHashMap extends SampleableConcurrentHashMap<Data,CacheRecord> implements Serializable

Class com.hazelcast.cache.impl.record.CacheRecordHashMap.EvictableSamplingEntry extends SampleableConcurrentHashMap.SamplingEntry implements Serializable


Package com.hazelcast.client

Class com.hazelcast.client.AuthenticationException extends HazelcastException implements Serializable


Package com.hazelcast.cluster.impl

Class com.hazelcast.cluster.impl.ConfigMismatchException extends HazelcastException implements Serializable


Package com.hazelcast.collection.common

Class com.hazelcast.collection.common.DataAwareItemEvent extends ItemEvent implements Serializable

serialVersionUID: 1L

Serialization Methods

writeObject

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

Package com.hazelcast.config

Class com.hazelcast.config.CacheConfig extends com.hazelcast.config.AbstractCacheConfig<K,V> implements Serializable

Serialized Fields

name

String name

managerPrefix

String managerPrefix

uriString

String uriString

asyncBackupCount

int asyncBackupCount

backupCount

int backupCount

inMemoryFormat

InMemoryFormat inMemoryFormat

evictionConfig

CacheEvictionConfig evictionConfig

nearCacheConfig

NearCacheConfig nearCacheConfig

Class com.hazelcast.config.CacheConfigReadOnly extends CacheConfig<K,V> implements Serializable

Class com.hazelcast.config.CacheEvictionConfig extends Object implements Serializable

Serialized Fields

size

int size

maxSizePolicy

CacheEvictionConfig.CacheMaxSizePolicy maxSizePolicy

evictionPolicy

EvictionPolicy evictionPolicy

readOnly

CacheEvictionConfigReadOnly readOnly

Class com.hazelcast.config.CacheEvictionConfigReadOnly extends CacheEvictionConfig implements Serializable

Class com.hazelcast.config.MaxSizeConfig extends Object implements Serializable

Serialized Fields

readOnly

MaxSizeConfigReadOnly readOnly

maxSizePolicy

MaxSizeConfig.MaxSizePolicy maxSizePolicy

size

int size

Class com.hazelcast.config.MaxSizeConfigReadOnly extends MaxSizeConfig implements Serializable

Class com.hazelcast.config.NearCacheConfig extends Object implements Serializable

Serialized Fields

timeToLiveSeconds

int timeToLiveSeconds

maxSize

int maxSize

evictionPolicy

String evictionPolicy

maxIdleSeconds

int maxIdleSeconds

invalidateOnChange

boolean invalidateOnChange

inMemoryFormat

InMemoryFormat inMemoryFormat

name

String name

readOnly

NearCacheConfigReadOnly readOnly

cacheLocalEntries

boolean cacheLocalEntries

localUpdatePolicy

NearCacheConfig.LocalUpdatePolicy localUpdatePolicy

Class com.hazelcast.config.NearCacheConfigReadOnly extends NearCacheConfig implements Serializable


Package com.hazelcast.console

Class com.hazelcast.console.SimulateLoadTask extends Object implements Serializable

serialVersionUID: 1L

Serialized Fields

delay

int delay

taskId

int taskId

latchId

String latchId

Package com.hazelcast.core

Class com.hazelcast.core.AbstractIMapEvent extends EventObject implements Serializable

Serialized Fields

name

String name

entryEventType

EntryEventType entryEventType

member

Member member

Class com.hazelcast.core.DuplicateInstanceNameException extends HazelcastException implements Serializable

Class com.hazelcast.core.EntryEvent extends AbstractIMapEvent implements Serializable

serialVersionUID: -2296203982913729851L

Serialized Fields

key

Object key

oldValue

Object oldValue

value

Object value

Class com.hazelcast.core.HazelcastException extends RuntimeException implements Serializable

Class com.hazelcast.core.HazelcastInstanceNotActiveException extends IllegalStateException implements Serializable

Class com.hazelcast.core.InitialMembershipEvent extends EventObject implements Serializable

serialVersionUID: -2010865371829087371L

Serialized Fields

members

Set<E> members

Class com.hazelcast.core.ItemEvent extends EventObject implements Serializable

Serialized Fields

item

Object item

eventType

ItemEventType eventType

member

Member member

Class com.hazelcast.core.MapEvent extends AbstractIMapEvent implements Serializable

serialVersionUID: -4948640313865667023L

Serialized Fields

numberOfEntriesAffected

int numberOfEntriesAffected
Number of entries affected by this event.

Class com.hazelcast.core.MemberAttributeEvent extends MembershipEvent implements Serializable

Serialized Fields

operationType

MemberAttributeOperationType operationType

key

String key

value

Object value

member

Member member

Class com.hazelcast.core.MemberLeftException extends ExecutionException implements Serializable

Serialization Methods

readObject

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

writeObject

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

Class com.hazelcast.core.MembershipEvent extends EventObject implements Serializable

serialVersionUID: -2010865371829087371L

Serialized Fields

member

Member member

eventType

int eventType

members

Set<E> members

Class com.hazelcast.core.Message extends EventObject implements Serializable

Serialized Fields

messageObject

Object messageObject

publishTime

long publishTime

publishingMember

Member publishingMember

Class com.hazelcast.core.OperationTimeoutException extends HazelcastException implements Serializable

Class com.hazelcast.core.RuntimeInterruptedException extends HazelcastException implements Serializable


Package com.hazelcast.hibernate

Class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory extends Object implements Serializable

Serialized Fields

instance

HazelcastInstance instance

cleanupService

CleanupService cleanupService

logger

ILogger logger

instanceLoader

IHazelcastInstanceLoader instanceLoader

Class com.hazelcast.hibernate.HazelcastCacheRegionFactory extends AbstractHazelcastCacheRegionFactory implements Serializable

Class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory extends AbstractHazelcastCacheRegionFactory implements Serializable


Package com.hazelcast.jca

Class com.hazelcast.jca.ConnectionFactoryImpl extends Object implements Serializable

serialVersionUID: -5909363703528221650L

Serialized Fields

mcf

ManagedConnectionFactoryImpl mcf
Access to this resource adapter infrastructure


cm

javax.resource.spi.ConnectionManager cm
Container's connection manager - i.e. for pooling


ref

Reference ref
JNDI reference - not used

Class com.hazelcast.jca.ManagedConnectionFactoryImpl extends JcaBase implements Serializable

serialVersionUID: -4889598421534961926L

Serialized Fields

resourceAdapter

ResourceAdapterImpl resourceAdapter
Access to this resource adapter instance itself


hzConnectionTracingEvents

Set<E> hzConnectionTracingEvents
Definies which events should be traced

See Also:
HzConnectionEvent

connectionTracingDetail

boolean connectionTracingDetail
Should connection events be traced or not

See Also:
ManagedConnectionFactoryImpl.hzConnectionTracingEvents

Class com.hazelcast.jca.ResourceAdapterImpl extends Object implements Serializable

serialVersionUID: -1727994229521767306L

Serialized Fields

configurationLocation

String configurationLocation
The configured hazelcast configuration location


Package com.hazelcast.logging

Class com.hazelcast.logging.LogEvent extends EventObject implements Serializable

Serialized Fields

logRecord

LogRecord logRecord

member

Member member

Package com.hazelcast.map

Class com.hazelcast.map.AbstractEntryProcessor extends Object implements Serializable

Serialized Fields

entryBackupProcessor

EntryBackupProcessor<K,V> entryBackupProcessor

Package com.hazelcast.map.impl

Class com.hazelcast.map.impl.DataAwareEntryEvent extends EntryEvent implements Serializable

serialVersionUID: 1L

Serialization Methods

writeObject

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

Class com.hazelcast.map.impl.MapEntrySimple extends AbstractMap.SimpleEntry<K,V> implements Serializable

Serialized Fields

modified

boolean modified

Package com.hazelcast.map.impl.mapstore.writebehind

Class com.hazelcast.map.impl.mapstore.writebehind.ReachedMaxSizeException extends RuntimeException implements Serializable

serialVersionUID: -2352370861668557606L

Class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent extends EventObject implements Serializable

serialVersionUID: -7071512331813330032L


Package com.hazelcast.mapreduce

Class com.hazelcast.mapreduce.LifecycleMapperAdapter extends Object implements Serializable

Class com.hazelcast.mapreduce.RemoteMapReduceException extends HazelcastException implements Serializable

Class com.hazelcast.mapreduce.TopologyChangedException extends HazelcastException implements Serializable


Package com.hazelcast.mapreduce.aggregation

Class com.hazelcast.mapreduce.aggregation.Supplier extends Object implements Serializable


Package com.hazelcast.mapreduce.aggregation.impl

Class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier extends Supplier<KeyIn,ValueIn,ValueOut> implements Serializable

Serialized Fields

propertyExtractor

PropertyExtractor<ValueIn,ValueOut> propertyExtractor

Class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier extends Supplier<KeyIn,ValueIn,ValueOut> implements Serializable

Serialized Fields

keyPredicate

KeyPredicate<Key> keyPredicate

chainedSupplier

Supplier<KeyIn,ValueIn,ValueOut> chainedSupplier

Class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier extends Supplier<KeyIn,ValueIn,ValueOut> implements Serializable

Serialized Fields

predicate

Predicate<K,V> predicate

chainedSupplier

Supplier<KeyIn,ValueIn,ValueOut> chainedSupplier

Class com.hazelcast.mapreduce.aggregation.impl.SetAdapter extends HashSet<E> implements Serializable


Package com.hazelcast.mapreduce.impl

Class com.hazelcast.mapreduce.impl.CombinerResultList extends ArrayList<E> implements Serializable

Class com.hazelcast.mapreduce.impl.HashMapAdapter extends HashMap<K,V> implements Serializable


Package com.hazelcast.nio.serialization

Class com.hazelcast.nio.serialization.HazelcastSerializationException extends HazelcastException implements Serializable


Package com.hazelcast.query

Class com.hazelcast.query.PagingPredicate extends Object implements Serializable

Serialized Fields

predicate

Predicate<K,V> predicate

comparator

Comparator<T> comparator

pageSize

int pageSize

page

int page

anchorMap

Map<K,V> anchorMap

iterationType

IterationType iterationType

Class com.hazelcast.query.PredicateBuilder extends Object implements Serializable

Serialized Fields

lsPredicates

List<E> lsPredicates

attribute

String attribute

Class com.hazelcast.query.Predicates.AbstractPredicate extends Object implements Serializable

Serialized Fields

attribute

String attribute

Class com.hazelcast.query.Predicates.AndPredicate extends Object implements Serializable

Serialized Fields

predicates

Predicate<K,V>[] predicates

Class com.hazelcast.query.Predicates.BetweenPredicate extends Predicates.AbstractPredicate implements Serializable

Serialized Fields

to

Comparable<T> to

from

Comparable<T> from

Class com.hazelcast.query.Predicates.EqualPredicate extends Predicates.AbstractPredicate implements Serializable

Serialized Fields

value

Comparable<T> value

Class com.hazelcast.query.Predicates.GreaterLessPredicate extends Predicates.EqualPredicate implements Serializable

Serialized Fields

equal

boolean equal

less

boolean less

Class com.hazelcast.query.Predicates.ILikePredicate extends Predicates.LikePredicate implements Serializable

Class com.hazelcast.query.Predicates.InPredicate extends Predicates.AbstractPredicate implements Serializable

Serialized Fields

values

Comparable<T>[] values

convertedInValues

Set<E> convertedInValues

Class com.hazelcast.query.Predicates.LikePredicate extends Object implements Serializable

Serialized Fields

attribute

String attribute

second

String second

pattern

Pattern pattern

Class com.hazelcast.query.Predicates.NotEqualPredicate extends Predicates.EqualPredicate implements Serializable

Class com.hazelcast.query.Predicates.NotPredicate extends Object implements Serializable

Serialized Fields

predicate

Predicate<K,V> predicate

Class com.hazelcast.query.Predicates.OrPredicate extends Object implements Serializable

Serialized Fields

predicates

Predicate<K,V>[] predicates

Class com.hazelcast.query.Predicates.RegexPredicate extends Object implements Serializable

Serialized Fields

attribute

String attribute

regex

String regex

pattern

Pattern pattern

Class com.hazelcast.query.QueryException extends HazelcastException implements Serializable

Class com.hazelcast.query.SqlPredicate extends Predicates.AbstractPredicate implements Serializable

serialVersionUID: 1L

Serialization Methods

readObject

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

sql

String sql

Class com.hazelcast.query.TruePredicate extends Object implements Serializable


Package com.hazelcast.security

Class com.hazelcast.security.AbstractCredentials extends Object implements Serializable

serialVersionUID: 3587995040707072446L

Serialized Fields

endpoint

String endpoint

principal

String principal

Class com.hazelcast.security.UsernamePasswordCredentials extends AbstractCredentials implements Serializable

serialVersionUID: -1508314631354255039L

Serialized Fields

password

byte[] password

Package com.hazelcast.security.permission

Class com.hazelcast.security.permission.AllPermissions extends ClusterPermission implements Serializable

Class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection extends PermissionCollection implements Serializable

Serialized Fields

all

boolean all

Class com.hazelcast.security.permission.AtomicLongPermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.AtomicReferencePermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.ClusterPermission extends Permission implements Serializable

Serialized Fields

hashcode

int hashcode

Class com.hazelcast.security.permission.ClusterPermissionCollection extends PermissionCollection implements Serializable

Serialized Fields

perms

Set<E> perms

permClass

Class<T> permClass

Class com.hazelcast.security.permission.CountDownLatchPermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.DenyAllPermissionCollection extends PermissionCollection implements Serializable

Class com.hazelcast.security.permission.ExecutorServicePermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.InstancePermission extends ClusterPermission implements Serializable

Serialized Fields

mask

int mask

actions

String actions

Class com.hazelcast.security.permission.ListPermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.LockPermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.MapPermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.MapReducePermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.MultiMapPermission extends MapPermission implements Serializable

Class com.hazelcast.security.permission.QueuePermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.ReplicatedMapPermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.SemaphorePermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.SetPermission extends ListPermission implements Serializable

Class com.hazelcast.security.permission.TopicPermission extends InstancePermission implements Serializable

Class com.hazelcast.security.permission.TransactionPermission extends ClusterPermission implements Serializable


Package com.hazelcast.spi

Class com.hazelcast.spi.MemberAttributeServiceEvent extends MemberAttributeEvent implements Serializable

Class com.hazelcast.spi.MembershipServiceEvent extends MembershipEvent implements Serializable

Class com.hazelcast.spi.PartitionMigrationEvent extends EventObject implements Serializable

Serialized Fields

migrationEndpoint

MigrationEndpoint migrationEndpoint

partitionId

int partitionId

Class com.hazelcast.spi.PartitionReplicationEvent extends EventObject implements Serializable

Serialized Fields

partitionId

int partitionId

replicaIndex

int replicaIndex

Package com.hazelcast.spi.exception

Class com.hazelcast.spi.exception.CallerNotMemberException extends RetryableHazelcastException implements Serializable

Class com.hazelcast.spi.exception.DistributedObjectDestroyedException extends HazelcastException implements Serializable

Class com.hazelcast.spi.exception.PartitionMigratingException extends RetryableHazelcastException implements Serializable

Class com.hazelcast.spi.exception.ResponseAlreadySentException extends HazelcastException implements Serializable

Class com.hazelcast.spi.exception.RetryableHazelcastException extends HazelcastException implements Serializable

Class com.hazelcast.spi.exception.RetryableIOException extends IOException implements Serializable

Class com.hazelcast.spi.exception.TargetDisconnectedException extends RetryableHazelcastException implements Serializable

Class com.hazelcast.spi.exception.TargetNotMemberException extends RetryableHazelcastException implements Serializable

Class com.hazelcast.spi.exception.WrongTargetException extends RetryableHazelcastException implements Serializable


Package com.hazelcast.topic.impl

Class com.hazelcast.topic.impl.DataAwareMessage extends Message implements Serializable

serialVersionUID: 1L

Serialization Methods

writeObject

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

Package com.hazelcast.transaction

Class com.hazelcast.transaction.TransactionException extends HazelcastException implements Serializable

Class com.hazelcast.transaction.TransactionNotActiveException extends HazelcastException implements Serializable

Class com.hazelcast.transaction.TransactionTimedOutException extends TransactionException implements Serializable


Package com.hazelcast.util

Class com.hazelcast.util.AddressUtil.InvalidAddressException extends IllegalArgumentException implements Serializable

Class com.hazelcast.util.CacheConcurrentHashMap extends ConcurrentReferenceHashMap<K,V> implements Serializable

Class com.hazelcast.util.ConcurrentReferenceHashMap extends AbstractMap<K,V> implements Serializable

serialVersionUID: 7249069246763182397L

Serialization Methods

readObject

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

Throws:
IOException
ClassNotFoundException

writeObject

private void writeObject(ObjectOutputStream s)
                  throws IOException
Save the state of the ConcurrentReferenceHashMap 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

com.hazelcast.util.ConcurrentReferenceHashMap.Segment<K,V>[] segments
The segments, each of which is a specialized hash table


identityComparisons

boolean identityComparisons

Class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry extends Object implements Serializable

serialVersionUID: -8499721149061103585L

Serialized Fields

key

Object key

value

Object value

Class com.hazelcast.util.ConcurrentReferenceHashMap.WriteThroughEntry extends ConcurrentReferenceHashMap.SimpleEntry<K,V> implements Serializable

serialVersionUID: -7900634345345313646L

Class com.hazelcast.util.SampleableConcurrentHashMap extends ConcurrentReferenceHashMap<K,V> implements Serializable

Class com.hazelcast.util.SampleableConcurrentHashMap.IterableSamplingEntry extends SampleableConcurrentHashMap.SamplingEntry implements Serializable

Serialized Fields

iterated

boolean iterated

Class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry extends ConcurrentReferenceHashMap.SimpleEntry<K,V> implements Serializable


Package com.hazelcast.web

Class com.hazelcast.web.AbstractWebDataEntryProcessor extends AbstractEntryProcessor<String,T> implements Serializable

Class com.hazelcast.web.AddSessionEntryProcessor extends AbstractWebDataEntryProcessor<Integer> implements Serializable

Class com.hazelcast.web.DestroySessionEntryProcessor extends AbstractWebDataEntryProcessor<Integer> implements Serializable

Class com.hazelcast.web.InvalidateSessionAttributesEntryProcessor extends AbstractWebDataEntryProcessor<Object> implements Serializable

Serialized Fields

sessionIdWithAttributeSeparator

String sessionIdWithAttributeSeparator

Class com.hazelcast.web.ReferenceSessionEntryProcessor extends AbstractWebDataEntryProcessor<Integer> implements Serializable

Class com.hazelcast.web.SessionAttributePredicate extends Object implements Serializable

Serialized Fields

sessionId

String sessionId



Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.