Serialized Form
-
Package com.hazelcast.aggregation
-
Class com.hazelcast.aggregation.AggregatorsSpecTest.Person
class Person extends Object implements Serializable-
Serialized Fields
-
bigDecimalValue
BigDecimal bigDecimalValue
-
bigIntegerValue
BigInteger bigIntegerValue
-
comparableValue
String comparableValue
-
doubleValue
Double doubleValue
-
fieldWeCanQuery
int fieldWeCanQuery
-
intValue
Integer intValue
-
longValue
Long longValue
-
-
-
Class com.hazelcast.aggregation.AggregatorsSpecTest.PersonAny
class PersonAny extends com.hazelcast.aggregation.AggregatorsSpecTest.Person implements Serializable-
Serialized Fields
-
bigDecimalValue
List<BigDecimal> bigDecimalValue
-
bigIntegerValue
List<BigInteger> bigIntegerValue
-
comparableValue
List<String> comparableValue
-
doubleValue
double[] doubleValue
-
intValue
int[] intValue
-
longValue
long[] longValue
-
-
-
-
Package com.hazelcast.cache
-
Class com.hazelcast.cache.BasicCacheLiteMemberTest.SimpleEntryListener
class SimpleEntryListener extends Object implements Serializable-
Serialized Fields
-
created
AtomicInteger created
-
expired
AtomicInteger expired
-
removed
AtomicInteger removed
-
updated
AtomicInteger updated
-
-
-
Class com.hazelcast.cache.CacheBasicAbstractTest.AppendEntryProcessor
class AppendEntryProcessor extends Object implements Serializable- serialVersionUID:
- -396575576353368113L
-
Class com.hazelcast.cache.CacheContextTest.TestListener
class TestListener extends Object implements Serializable -
Class com.hazelcast.cache.CacheFromDifferentNodesTest.SimpleEntryListener
class SimpleEntryListener extends Object implements Serializable-
Serialized Fields
-
created
AtomicInteger created
-
expired
AtomicInteger expired
-
removed
AtomicInteger removed
-
updated
AtomicInteger updated
-
-
-
Class com.hazelcast.cache.CacheListenerTest.TestListener
class TestListener extends Object implements Serializable-
Serialized Fields
-
counter
AtomicInteger counter
-
-
-
Exception com.hazelcast.cache.CacheNotExistsException
class CacheNotExistsException extends IllegalStateException implements Serializable -
Class com.hazelcast.cache.CacheReadWriteThroughTest.GetAllAsyncCacheLoader
class GetAllAsyncCacheLoader extends Object implements Serializable-
Serialized Fields
-
throwError
boolean throwError
-
-
-
Class com.hazelcast.cache.CacheReadWriteThroughTest.MaxValueChecker
class MaxValueChecker extends Object implements Serializable-
Serialized Fields
-
maxValue
int maxValue
-
-
-
Class com.hazelcast.cache.CacheReadWriteThroughTest.ModValueChecker
class ModValueChecker extends Object implements Serializable-
Serialized Fields
-
mod
int mod
-
-
-
Class com.hazelcast.cache.CacheReadWriteThroughTest.PutCacheWriter
class PutCacheWriter extends Object implements Serializable-
Serialized Fields
-
valueChecker
com.hazelcast.cache.CacheReadWriteThroughTest.ValueChecker valueChecker
-
-
-
Class com.hazelcast.cache.HazelcastExpiryPolicy
class HazelcastExpiryPolicy extends Object implements Serializable-
Serialized Fields
-
access
javax.cache.expiry.Duration access
-
create
javax.cache.expiry.Duration create
-
update
javax.cache.expiry.Duration update
-
-
-
-
Package com.hazelcast.client
-
Exception com.hazelcast.client.AuthenticationException
class AuthenticationException extends HazelcastException implements Serializable -
Exception com.hazelcast.client.ClientNotAllowedInClusterException
class ClientNotAllowedInClusterException extends HazelcastException implements Serializable -
Class com.hazelcast.client.ClientRegressionWithMockNetworkTest.MyCredentials
class MyCredentials extends UsernamePasswordCredentials implements Serializable -
Class com.hazelcast.client.ClientTimeoutTest.RetryableExceptionThrowingCallable
class RetryableExceptionThrowingCallable extends Object implements Serializable -
Exception com.hazelcast.client.HazelcastClientNotActiveException
class HazelcastClientNotActiveException extends IllegalStateException implements Serializable -
Exception com.hazelcast.client.HazelcastClientOfflineException
class HazelcastClientOfflineException extends IllegalStateException implements Serializable -
Class com.hazelcast.client.TcpClientConnectionTest.DummySerializableCallable
class DummySerializableCallable extends Object implements Serializable -
Exception com.hazelcast.client.UndefinedErrorCodeException
class UndefinedErrorCodeException extends HazelcastException implements Serializable-
Serialized Fields
-
className
String className
-
-
-
Exception com.hazelcast.client.UnsupportedClusterVersionException
class UnsupportedClusterVersionException extends HazelcastException implements Serializable -
Exception com.hazelcast.client.UnsupportedRoutingModeException
class UnsupportedRoutingModeException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.cluster
-
Class com.hazelcast.cluster.InitialMembershipEvent
class InitialMembershipEvent extends EventObject implements Serializable- serialVersionUID:
- -2010865371829087371L
-
Class com.hazelcast.cluster.MembershipEvent
class MembershipEvent extends EventObject implements Serializable- serialVersionUID:
- -2010865371829087371L
-
-
Package com.hazelcast.collection
-
Class com.hazelcast.collection.ItemEvent
class ItemEvent extends EventObject implements Serializable-
Serialized Fields
-
eventType
ItemEventType eventType
-
item
E item
-
member
Member member
-
-
-
-
Package com.hazelcast.config
-
Class com.hazelcast.config.AbstractCacheConfig
class AbstractCacheConfig extends Object implements Serializable-
Serialized Fields
-
cacheLoaderFactory
com.hazelcast.cache.impl.DeferredValue<javax.cache.configuration.Factory<javax.cache.integration.CacheLoader<K extends Object,
V extends Object>>> cacheLoaderFactory -
cacheWriterFactory
com.hazelcast.cache.impl.DeferredValue<javax.cache.configuration.Factory<javax.cache.integration.CacheWriter<? super K extends Object,
? super V extends Object>>> cacheWriterFactory -
dataPersistenceConfig
com.hazelcast.config.DataPersistenceConfig dataPersistenceConfig
-
eventJournalConfig
com.hazelcast.config.EventJournalConfig eventJournalConfig
-
expiryPolicyFactory
com.hazelcast.cache.impl.DeferredValue<javax.cache.configuration.Factory<javax.cache.expiry.ExpiryPolicy>> expiryPolicyFactory
-
hotRestartConfig
com.hazelcast.config.HotRestartConfig hotRestartConfig
-
isManagementEnabled
boolean isManagementEnabled
-
isReadThrough
boolean isReadThrough
-
isStatisticsEnabled
boolean isStatisticsEnabled
-
isStoreByValue
boolean isStoreByValue
-
isWriteThrough
boolean isWriteThrough
-
keyClassName
String keyClassName
-
keyType
Class<K extends Object> keyType
-
listenerConfigurations
Set<com.hazelcast.cache.impl.DeferredValue<javax.cache.configuration.CacheEntryListenerConfiguration<K extends Object,
V extends Object>>> listenerConfigurations -
valueClassName
String valueClassName
-
valueType
Class<V extends Object> valueType
-
-
-
Class com.hazelcast.config.CacheConfig
class CacheConfig extends com.hazelcast.config.AbstractCacheConfig<K extends Object,V extends Object> implements Serializable -
Serialized Fields
-
asyncBackupCount
int asyncBackupCount
-
backupCount
int backupCount
-
disablePerEntryInvalidationEvents
boolean disablePerEntryInvalidationEvents
-
evictionConfig
EvictionConfig evictionConfig
-
inMemoryFormat
InMemoryFormat inMemoryFormat
-
managerPrefix
String managerPrefix
-
mergePolicyConfig
com.hazelcast.config.MergePolicyConfig mergePolicyConfig
-
merkleTreeConfig
com.hazelcast.config.MerkleTreeConfig merkleTreeConfig
-
name
String name
-
partitionLostListenerConfigs
List<com.hazelcast.config.CachePartitionLostListenerConfig> partitionLostListenerConfigs
-
splitBrainProtectionName
String splitBrainProtectionName
-
uriString
String uriString
-
userCodeNamespace
String userCodeNamespace
-
wanReplicationRef
com.hazelcast.config.WanReplicationRef wanReplicationRef
-
-
-
Class com.hazelcast.config.CacheConfigTest.EntryListenerFactory
class EntryListenerFactory extends Object implements Serializable -
Class com.hazelcast.config.CacheConfigTest.MyCacheLoaderFactory
class MyCacheLoaderFactory extends Object implements Serializable -
Class com.hazelcast.config.CacheConfigTest.MyCacheWriterFactory
class MyCacheWriterFactory extends Object implements Serializable -
Class com.hazelcast.config.CacheConfigTest.MyEntryEventFilterFactory
class MyEntryEventFilterFactory extends Object implements Serializable -
Class com.hazelcast.config.CacheConfigTest.MyEntryListenerFactory
class MyEntryListenerFactory extends Object implements Serializable -
Class com.hazelcast.config.CacheConfigTest.MyExpirePolicyFactory
class MyExpirePolicyFactory extends Object implements Serializable -
Class com.hazelcast.config.CacheConfigTest.MySyncEntryEventFilterFactory
class MySyncEntryEventFilterFactory extends Object implements Serializable -
Class com.hazelcast.config.CacheConfigTest.MySyncEntryListenerFactory
class MySyncEntryListenerFactory extends Object implements Serializable -
Class com.hazelcast.config.CachePartitionLostListenerConfig
class CachePartitionLostListenerConfig extends ListenerConfig implements Serializable -
Class com.hazelcast.config.DummyWanConsumer
class DummyWanConsumer extends Object implements Serializable -
Class com.hazelcast.config.DummyWanPublisher
class DummyWanPublisher extends Object implements Serializable -
Class com.hazelcast.config.EvictionConfig
class EvictionConfig extends Object implements Serializable-
Serialized Fields
-
comparator
EvictionPolicyComparator comparator
-
comparatorClassName
String comparatorClassName
-
evictionPolicy
EvictionPolicy evictionPolicy
-
maxSizePolicy
MaxSizePolicy maxSizePolicy
-
size
int size
-
sizeConfigured
boolean sizeConfigured
Used by theNearCacheConfigAccessor
to initialize the proper default value for on-heap maps.
-
-
-
Exception com.hazelcast.config.InvalidConfigurationException
class InvalidConfigurationException extends HazelcastException implements Serializable -
Class com.hazelcast.config.NearCacheConfig
class NearCacheConfig extends Object implements Serializable-
Serialized Fields
-
cacheLocalEntries
boolean cacheLocalEntries
-
evictionConfig
EvictionConfig evictionConfig
-
inMemoryFormat
InMemoryFormat inMemoryFormat
-
invalidateOnChange
boolean invalidateOnChange
-
localUpdatePolicy
NearCacheConfig.LocalUpdatePolicy localUpdatePolicy
-
maxIdleSeconds
int maxIdleSeconds
-
name
String name
-
preloaderConfig
NearCachePreloaderConfig preloaderConfig
-
serializeKeys
boolean serializeKeys
-
timeToLiveSeconds
int timeToLiveSeconds
-
-
-
Class com.hazelcast.config.NearCachePreloaderConfig
class NearCachePreloaderConfig extends Object implements Serializable-
Serialized Fields
-
directory
String directory
-
enabled
boolean enabled
-
storeInitialDelaySeconds
int storeInitialDelaySeconds
-
storeIntervalSeconds
int storeIntervalSeconds
-
-
-
Class com.hazelcast.config.WanReplicationRef
class WanReplicationRef extends Object implements Serializable
-
-
Package com.hazelcast.config.properties
-
Exception com.hazelcast.config.properties.ValidationException
class ValidationException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.core
-
Exception com.hazelcast.core.ConsistencyLostException
class ConsistencyLostException extends HazelcastException implements Serializable -
Class com.hazelcast.core.DistributedObjectEvent
class DistributedObjectEvent extends EventObject implements Serializable- serialVersionUID:
- -4532279189146831926L
-
Serialized Fields
-
distributedObject
DistributedObject distributedObject
-
eventType
DistributedObjectEvent.EventType eventType
-
objectName
String objectName
-
serviceName
String serviceName
-
-
Class com.hazelcast.core.EntryEvent
class EntryEvent extends AbstractIMapEvent implements Serializable- serialVersionUID:
- -2296203982913729851L
-
Exception com.hazelcast.core.HazelcastException
class HazelcastException extends RuntimeException implements Serializable -
Exception com.hazelcast.core.HazelcastInstanceNotActiveException
class HazelcastInstanceNotActiveException extends IllegalStateException implements Serializable -
Exception com.hazelcast.core.HazelcastOverloadException
class HazelcastOverloadException extends HazelcastException implements Serializable -
Exception com.hazelcast.core.IndeterminateOperationStateException
class IndeterminateOperationStateException extends HazelcastException implements Serializable -
Exception com.hazelcast.core.LocalMemberResetException
class LocalMemberResetException extends HazelcastException implements Serializable -
Exception com.hazelcast.core.MemberLeftException
class MemberLeftException extends ExecutionException implements Serializable-
Serialization Methods
-
readObject
- Throws:
IOException
ClassNotFoundException
-
writeObject
- Throws:
IOException
-
-
-
Exception com.hazelcast.core.OperationTimeoutException
class OperationTimeoutException extends HazelcastException implements Serializable -
Exception com.hazelcast.core.RuntimeInterruptedException
class RuntimeInterruptedException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.cp.exception
-
Exception com.hazelcast.cp.exception.CannotReplicateException
class CannotReplicateException extends CPSubsystemException implements Serializable- serialVersionUID:
- 4407025930140337716L
-
Exception com.hazelcast.cp.exception.CPGroupDestroyedException
class CPGroupDestroyedException extends CPSubsystemException implements Serializable- serialVersionUID:
- -5363753263443789491L
-
Serialized Fields
-
groupId
CPGroupId groupId
-
-
Exception com.hazelcast.cp.exception.CPSubsystemException
class CPSubsystemException extends HazelcastException implements Serializable- serialVersionUID:
- 3165333502175586105L
-
Serialized Fields
-
leaderUuid
UUID leaderUuid
-
-
Exception com.hazelcast.cp.exception.LeaderDemotedException
class LeaderDemotedException extends CPSubsystemException implements Serializable- serialVersionUID:
- 4284556927980596355L
-
Exception com.hazelcast.cp.exception.NotLeaderException
class NotLeaderException extends CPSubsystemException implements Serializable- serialVersionUID:
- 1817579502149525710L
-
Exception com.hazelcast.cp.exception.StaleAppendRequestException
class StaleAppendRequestException extends CPSubsystemException implements Serializable- serialVersionUID:
- -736303015926722821L
-
-
Package com.hazelcast.cp.lock.exception
-
Exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
class LockAcquireLimitReachedException extends HazelcastException implements Serializable -
Exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
class LockOwnershipLostException extends IllegalMonitorStateException implements Serializable
-
-
Package com.hazelcast.crdt
-
Exception com.hazelcast.crdt.MutationDisallowedException
class MutationDisallowedException extends HazelcastException implements Serializable -
Exception com.hazelcast.crdt.TargetNotReplicaException
class TargetNotReplicaException extends RetryableHazelcastException implements Serializable
-
-
Package com.hazelcast.function
-
Class com.hazelcast.function.ComparatorsEx.NullComparator
class NullComparator extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
isNullFirst
boolean isNullFirst
-
-
-
Package com.hazelcast.logging
-
Class com.hazelcast.logging.LogEvent
class LogEvent extends EventObject implements Serializable
-
-
Package com.hazelcast.map
-
Class com.hazelcast.map.AbstractEntryEventTypesTest.Person
class Person extends Object implements Serializable-
Serialized Fields
-
age
int age
-
name
String name
-
-
-
Class com.hazelcast.map.AbstractIMapEvent
class AbstractIMapEvent extends EventObject implements Serializable-
Serialized Fields
-
entryEventType
EntryEventType entryEventType
-
member
Member member
-
name
String name
-
-
-
Class com.hazelcast.map.AbstractMapQueryIterableTest.GetValueProjection
class GetValueProjection extends Object implements Serializable -
Class com.hazelcast.map.AbstractMapQueryIterableTest.TestProjection
class TestProjection extends Object implements Serializable -
Class com.hazelcast.map.BackupExpirationTest.BackupExpirationQueueLengthFinder
class BackupExpirationQueueLengthFinder extends Object implements Serializable -
Class com.hazelcast.map.BackupExpirationTest.BackupExpiryTimeReader
class BackupExpiryTimeReader extends Object implements Serializable-
Serialized Fields
-
mapName
String mapName
-
-
-
Class com.hazelcast.map.BackupExpirationTest.ExpiryTimeReader
class ExpiryTimeReader extends Object implements Serializable-
Serialized Fields
-
mapName
String mapName
-
-
-
Class com.hazelcast.map.EntryLoadedListenerTest.Reader
class Reader extends Object implements Serializable -
Class com.hazelcast.map.EntryLoadedListenerTest.Updater
class Updater extends Object implements Serializable -
Class com.hazelcast.map.EntryProcessorTest.JsonPutEntryProcessor
class JsonPutEntryProcessor extends Object implements Serializable -
Class com.hazelcast.map.InMemoryFormatTest.Pair
class Pair extends Object implements Serializable -
Class com.hazelcast.map.InterceptorTest.SimpleInterceptor
class SimpleInterceptor extends com.hazelcast.map.MapInterceptorAdaptor implements Serializable- serialVersionUID:
- 1L
-
Class com.hazelcast.map.IssuesTest.CompositeKey
class CompositeKey extends Object implements Serializable -
Class com.hazelcast.map.MapEvent
class MapEvent extends AbstractIMapEvent implements Serializable- serialVersionUID:
- -4948640313865667023L
-
Serialized Fields
-
numberOfEntriesAffected
int numberOfEntriesAffected
Number of entries affected by this event.
-
-
Class com.hazelcast.map.MapIndexBackupTest.Book
class Book extends Object implements Serializable -
Class com.hazelcast.map.MapIndexLifecycleTest.Book
class Book extends Object implements Serializable -
Class com.hazelcast.map.MapInstanceSharingTest.DummyObject
class DummyObject extends Object implements Serializable -
Class com.hazelcast.map.MapInterceptorAdaptor
class MapInterceptorAdaptor extends Object implements Serializable- serialVersionUID:
- 1L
-
Class com.hazelcast.map.MapPartitionLostEvent
class MapPartitionLostEvent extends AbstractIMapEvent implements Serializable- serialVersionUID:
- -7445734640964238109L
-
Serialized Fields
-
partitionId
int partitionId
-
-
Exception com.hazelcast.map.QueryResultSizeExceededException
class QueryResultSizeExceededException extends HazelcastException implements Serializable -
Exception com.hazelcast.map.ReachedMaxSizeException
class ReachedMaxSizeException extends RuntimeException implements Serializable- serialVersionUID:
- -2352370861668557606L
-
Class com.hazelcast.map.TestLoggingEntryProcessor
class TestLoggingEntryProcessor extends Object implements Serializable- serialVersionUID:
- 1L
-
-
Package com.hazelcast.memory
-
Error com.hazelcast.memory.NativeOutOfMemoryError
class NativeOutOfMemoryError extends Error implements Serializable
-
-
Package com.hazelcast.nio.serialization
-
Exception com.hazelcast.nio.serialization.HazelcastSerializationException
class HazelcastSerializationException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.partition
-
Exception com.hazelcast.partition.NoDataMemberInClusterException
class NoDataMemberInClusterException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.partition.strategy
-
Class com.hazelcast.partition.strategy.AttributePartitioningStrategy
class AttributePartitioningStrategy extends Object implements Serializable-
Serialized Fields
-
attributes
String[] attributes
-
-
-
Class com.hazelcast.partition.strategy.AttributePartitioningStrategyIntegrationTest.JavaKey
class JavaKey extends Object implements Serializable -
Class com.hazelcast.partition.strategy.AttributePartitioningStrategyTest.RegularPojo
class RegularPojo extends Object implements Serializable -
Class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
class DefaultPartitioningStrategy extends Object implements Serializable -
Class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
class StringAndPartitionAwarePartitioningStrategy extends Object implements Serializable -
Class com.hazelcast.partition.strategy.StringPartitioningStrategy
class StringPartitioningStrategy extends Object implements Serializable
-
-
Package com.hazelcast.projection
-
Class com.hazelcast.projection.MapProjectionTest.ExceptionThrowingProjection
class ExceptionThrowingProjection extends Object implements Serializable -
Class com.hazelcast.projection.MapProjectionTest.NullReturningProjection
class NullReturningProjection extends Object implements Serializable -
Class com.hazelcast.projection.MapProjectionTest.ObjectValueIncrementingProjection
class ObjectValueIncrementingProjection extends Object implements Serializable -
Class com.hazelcast.projection.MapProjectionTest.PrimitiveValueIncrementingProjection
class PrimitiveValueIncrementingProjection extends Object implements Serializable
-
-
Package com.hazelcast.query
-
Exception com.hazelcast.query.QueryException
class QueryException extends HazelcastException implements Serializable -
Class com.hazelcast.query.SampleTestObjects.Employee
class Employee extends Object implements Serializable -
Class com.hazelcast.query.SampleTestObjects.ObjectWithBigDecimal
class ObjectWithBigDecimal extends Object implements Serializable-
Serialized Fields
-
attribute
BigDecimal attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithBigInteger
class ObjectWithBigInteger extends Object implements Serializable-
Serialized Fields
-
attribute
BigInteger attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithBoolean
class ObjectWithBoolean extends Object implements Serializable-
Serialized Fields
-
attribute
boolean attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithByte
class ObjectWithByte extends Object implements Serializable-
Serialized Fields
-
attribute
byte attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithChar
class ObjectWithChar extends Object implements Serializable-
Serialized Fields
-
attribute
char attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithDate
class ObjectWithDate extends Object implements Serializable-
Serialized Fields
-
attribute
Date attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithDouble
class ObjectWithDouble extends Object implements Serializable-
Serialized Fields
-
attribute
double attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithFloat
class ObjectWithFloat extends Object implements Serializable-
Serialized Fields
-
attribute
float attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithInteger
class ObjectWithInteger extends Object implements Serializable-
Serialized Fields
-
attribute
int attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithLong
class ObjectWithLong extends Object implements Serializable-
Serialized Fields
-
attribute
long attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithOptional
class ObjectWithOptional extends Object implements Serializable-
Serialized Fields
-
attribute
T extends Object attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithShort
class ObjectWithShort extends Object implements Serializable-
Serialized Fields
-
attribute
short attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithSqlDate
class ObjectWithSqlDate extends Object implements Serializable-
Serialized Fields
-
attribute
Date attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithSqlTimestamp
class ObjectWithSqlTimestamp extends Object implements Serializable-
Serialized Fields
-
attribute
Timestamp attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.ObjectWithUUID
class ObjectWithUUID extends Object implements Serializable-
Serialized Fields
-
attribute
UUID attribute
-
-
-
Class com.hazelcast.query.SampleTestObjects.SpiedEmployee
class SpiedEmployee extends com.hazelcast.query.SampleTestObjects.Employee implements Serializable-
Serialized Fields
-
invocationCounters
Map<String,
AtomicInteger> invocationCounters
-
-
-
Class com.hazelcast.query.SampleTestObjects.Value
class Value extends Object implements Serializable-
Serialized Fields
-
index
int index
-
name
String name
-
state
com.hazelcast.query.SampleTestObjects.State state
-
type
com.hazelcast.query.SampleTestObjects.ValueType type
-
-
-
Class com.hazelcast.query.SampleTestObjects.ValueType
class ValueType extends Object implements Serializable-
Serialized Fields
-
typeName
String typeName
-
-
-
-
Package com.hazelcast.replicatedmap
-
Exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
class ReplicatedMapCantBeCreatedOnLiteMemberException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.ringbuffer
-
Exception com.hazelcast.ringbuffer.StaleSequenceException
class StaleSequenceException extends RuntimeException implements Serializable-
Serialized Fields
-
headSeq
long headSeq
-
-
-
-
Package com.hazelcast.scheduledexecutor
-
Exception com.hazelcast.scheduledexecutor.DuplicateTaskException
class DuplicateTaskException extends HazelcastException implements Serializable -
Exception com.hazelcast.scheduledexecutor.StaleTaskException
class StaleTaskException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.security
-
Class com.hazelcast.security.SimpleTokenCredentials
class SimpleTokenCredentials extends Object implements Serializable- serialVersionUID:
- -1508314631354255039L
-
Serialized Fields
-
token
byte[] token
-
-
Class com.hazelcast.security.UsernamePasswordCredentials
class UsernamePasswordCredentials extends Object implements Serializable- serialVersionUID:
- -1508314631354255039L
-
-
Package com.hazelcast.spi.eviction
-
Package com.hazelcast.spi.exception
-
Exception com.hazelcast.spi.exception.CallerNotMemberException
class CallerNotMemberException extends RetryableHazelcastException implements Serializable -
Exception com.hazelcast.spi.exception.DistributedObjectDestroyedException
class DistributedObjectDestroyedException extends HazelcastException implements Serializable -
Exception com.hazelcast.spi.exception.NoCredentialsException
class NoCredentialsException extends RuntimeException implements Serializable -
Exception com.hazelcast.spi.exception.PartitionMigratingException
class PartitionMigratingException extends RetryableHazelcastException implements Serializable -
Exception com.hazelcast.spi.exception.ResponseAlreadySentException
class ResponseAlreadySentException extends HazelcastException implements Serializable -
Exception com.hazelcast.spi.exception.RestClientException
class RestClientException extends RuntimeException implements Serializable-
Serialized Fields
-
httpErrorCode
int httpErrorCode
-
-
-
Exception com.hazelcast.spi.exception.RetryableHazelcastException
class RetryableHazelcastException extends HazelcastException implements Serializable -
Exception com.hazelcast.spi.exception.RetryableIOException
class RetryableIOException extends IOException implements Serializable -
Exception com.hazelcast.spi.exception.ServiceNotFoundException
class ServiceNotFoundException extends HazelcastException implements Serializable -
Exception com.hazelcast.spi.exception.TargetDisconnectedException
class TargetDisconnectedException extends HazelcastException implements Serializable -
Exception com.hazelcast.spi.exception.TargetNotMemberException
class TargetNotMemberException extends RetryableHazelcastException implements Serializable- serialVersionUID:
- -3791433456807089118L
-
Exception com.hazelcast.spi.exception.WrongTargetException
class WrongTargetException extends RetryableHazelcastException implements Serializable- serialVersionUID:
- -84600702836709317L
-
-
Package com.hazelcast.splitbrainprotection
-
Class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
class SplitBrainProtectionEvent extends EventObject implements Serializable-
Serialized Fields
-
currentMembers
Collection<Member> currentMembers
-
presence
boolean presence
-
threshold
int threshold
-
-
-
Exception com.hazelcast.splitbrainprotection.SplitBrainProtectionException
class SplitBrainProtectionException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.topic
-
Class com.hazelcast.topic.Message
class Message extends EventObject implements Serializable -
Exception com.hazelcast.topic.TopicOverloadException
class TopicOverloadException extends HazelcastException implements Serializable
-
-
Package com.hazelcast.version
-
Class com.hazelcast.version.MemberVersion
class MemberVersion extends Object implements Serializable- serialVersionUID:
- 2603770920931610781L
-
Serialized Fields
-
major
byte major
-
minor
byte minor
-
patch
byte patch
-
-