Package | Description |
---|---|
com.hazelcast.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.journal | |
com.hazelcast.cache.impl.merge.entry |
This package contains merge entry internal interfaces and functionality for Hazelcast cache.
|
com.hazelcast.cache.impl.record |
Hazelcast JSR-107 aka JCache implementation
Internal record store
|
com.hazelcast.cardinality.impl.hyperloglog |
This package contains spec for the HyperLogLog data-structure.
|
com.hazelcast.cardinality.impl.hyperloglog.impl |
This package contains implementations of
HyperLogLog . |
com.hazelcast.concurrent.lock | |
com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
com.hazelcast.config |
Provides classes for configuring HazelcastInstance.
|
com.hazelcast.cp.internal.raftop.metadata |
Contains operations that are used in the Metadata CP group
|
com.hazelcast.instance |
This package contains Hazelcast Instance functionality.
|
com.hazelcast.internal.cluster |
Contains the internals for cluster management like discovery, joining etc.
|
com.hazelcast.internal.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.internal.cluster.impl.operations |
This package contains operations for the com.hazelcast.cluster.impl package.
|
com.hazelcast.internal.management.operation |
Contains operations that are called from Management Center.
|
com.hazelcast.internal.management.request |
Contains requests that made from Management Center.
|
com.hazelcast.internal.partition |
Contains the internals for partition assignment/management, migration, replication etc.
|
com.hazelcast.internal.partition.operation |
Contains the operations for partition package.
|
com.hazelcast.internal.usercodedeployment.impl | |
com.hazelcast.map.impl |
Contains implementation specific classes of
com.hazelcast.map package. |
com.hazelcast.map.impl.journal | |
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.record |
Contains record specific classes.
|
com.hazelcast.map.impl.tx |
Contains implementation classes for
TransactionalMap |
com.hazelcast.multimap.impl.operations |
Contains operations for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.txn |
This package contains the Transaction behavior for the Multimap.
|
com.hazelcast.replicatedmap.impl.record |
This package contains the implementation of the backing data storage for the replicated map implementation
|
com.hazelcast.ringbuffer.impl |
Contains the
Ringbuffer implementation classes. |
com.hazelcast.ringbuffer.impl.operations | |
com.hazelcast.scheduledexecutor.impl | |
com.hazelcast.spi.impl.eventservice.impl.operations |
Contains the operations for the
EventServiceImpl . |
com.hazelcast.spi.impl.merge |
This package contains split-brain related classes.
|
Modifier and Type | Class and Description |
---|---|
class |
PreJoinCacheConfig<K,V>
This subclass of
CacheConfig is used to communicate cache configurations in pre-join cache operations when cluster
version is at least 3.9. |
Modifier and Type | Class and Description |
---|---|
class |
CacheEventJournalReadResultSetImpl<K,V,T> |
Modifier and Type | Class and Description |
---|---|
class |
DefaultCacheEntryView
Default heap based implementation of
CacheEntryView . |
Modifier and Type | Interface and Description |
---|---|
interface |
CacheRecord<V,E>
An expirable and evictable data object which represents a cache entry.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCacheRecord<V,E>
Abstract implementation of
CacheRecord with key, value and
expiration time as internal state. |
class |
CacheDataRecord
Implementation of
CacheRecord where value has an internal serialized format. |
class |
CacheObjectRecord
Implementation of
CacheRecord which has an internal object format. |
Modifier and Type | Interface and Description |
---|---|
interface |
HyperLogLog
HyperLogLog is a redundant and highly available distributed data-structure used for cardinality estimation
purposes on unique items in significantly sized data cultures.
|
Modifier and Type | Class and Description |
---|---|
class |
HyperLogLogImpl |
class |
SparseHyperLogLogEncoder
1.
|
Modifier and Type | Class and Description |
---|---|
class |
LockStoreImpl |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLockOperation |
class |
AwaitBackupOperation |
class |
AwaitOperation |
class |
BeforeAwaitBackupOperation |
class |
BeforeAwaitOperation |
class |
GetLockCountOperation |
class |
GetRemainingLeaseTimeOperation |
class |
IsLockedOperation |
class |
LocalLockCleanupOperation
Locally executed operation which unlocks a lock if it is held by a
specific owner.
|
class |
LockBackupOperation |
class |
LockOperation |
class |
LockReplicationOperation |
class |
SignalBackupOperation |
class |
SignalOperation |
class |
UnlockBackupOperation |
class |
UnlockIfLeaseExpiredOperation |
class |
UnlockOperation |
Modifier and Type | Class and Description |
---|---|
class |
CardinalityEstimatorConfig
Configuration options for the
CardinalityEstimator |
class |
CollectionConfig<T extends CollectionConfig>
Provides configuration service for Collection.
|
class |
CountDownLatchConfig
Contains the configuration for an
ICountDownLatch . |
class |
DurableExecutorConfig
Contains the configuration for an
DurableExecutorService . |
class |
ExecutorConfig
Contains the configuration for an
IExecutorService . |
class |
ExecutorConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
ListConfig
Contains the configuration for an
IList . |
class |
ListConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapConfig
Contains the configuration for an
IMap . |
class |
MapConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MultiMapConfig
Configuration for MultiMap.
|
class |
MultiMapConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
QueueConfig
Contains the configuration for an
IQueue . |
class |
QueueConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
ReplicatedMapConfig
Contains the configuration for an
ReplicatedMap |
class |
RingbufferConfig
Contains the configuration for the
Ringbuffer . |
class |
ScheduledExecutorConfig
Configuration options for the
IScheduledExecutorService . |
class |
SemaphoreConfig
Contains the configuration for an
ISemaphore . |
class |
SemaphoreConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
SetConfig
Contains the configuration for an
ISet . |
class |
SetConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
WanConsumerConfig
Config for processing WAN events received from a target cluster.
|
class |
WanPublisherConfig
Configuration object for a WAN publisher.
|
class |
WanReplicationConfig
Configuration for WAN replication.
|
Modifier and Type | Class and Description |
---|---|
class |
RaftServicePreJoinOp
If the CP subsystem discovery process is completed, new Hazelcast nodes
skip the discovery step.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMember |
class |
MemberImpl |
Modifier and Type | Class and Description |
---|---|
class |
MemberInfo |
Modifier and Type | Class and Description |
---|---|
class |
ClusterStateTransactionLogRecord
TransactionLogRecord implementation to be used in
ClusterState transactions. |
class |
MembersView
MembersView is a container object to carry member list and version together.
|
class |
SplitBrainJoinMessage
A
JoinMessage issued by the master node of a subcluster to the master of another subcluster
while searching for other clusters for split brain recovery. |
Modifier and Type | Class and Description |
---|---|
class |
FinalizeJoinOp
Sent by the master to all members to finalize the join operation from a joining/returning node.
|
class |
HeartbeatOp
A heartbeat sent from one cluster member to another.
|
class |
LockClusterStateOp |
class |
MembersUpdateOp |
Modifier and Type | Class and Description |
---|---|
class |
AddWanConfigLegacyOperation
Operation to add a new
WanReplicationConfig at runtime. |
class |
ScriptExecutorOperation
Operation to execute script on the node.
|
Modifier and Type | Class and Description |
---|---|
static class |
GetCacheEntryRequest.CacheBrowserEntryView |
Modifier and Type | Class and Description |
---|---|
class |
MigrationInfo |
class |
PartitionRuntimeState |
Modifier and Type | Class and Description |
---|---|
class |
MigrationCommitOperation
Sent by the master node to commit a migration on the migration destination.
|
class |
MigrationOperation
Migration operation used by Hazelcast version 3.9
It runs on the migration destination and applies the received fragments.
|
class |
MigrationRequestOperation
Migration request operation used by Hazelcast version 3.9
Sent from the master node to the partition owner.
|
class |
PartitionBackupReplicaAntiEntropyOperation |
class |
PartitionReplicaSyncRequest
The request sent from a replica to the partition owner to synchronize the replica data.
|
class |
PartitionReplicaSyncResponse
The replica synchronization response sent from the partition owner to a replica.
|
class |
PartitionReplicaSyncRetryResponse
The response to a
PartitionReplicaSyncRequest that the replica should retry. |
class |
PartitionStateOperation
Sent from the master to publish or sync the partition table state to all cluster members.
|
class |
PromotionCommitOperation
Used for committing a promotion on destination.
|
Modifier and Type | Class and Description |
---|---|
class |
ClassData
Carries byte code of a class along with its inner classes.
|
Modifier and Type | Class and Description |
---|---|
class |
SimpleEntryView<K,V>
SimpleEntryView is an implementation of
EntryView and also it is writable. |
Modifier and Type | Class and Description |
---|---|
class |
MapEventJournalReadResultSetImpl<K,V,T> |
Modifier and Type | Class and Description |
---|---|
class |
RecordInfo
Record info.
|
class |
RecordReplicationInfo |
Modifier and Type | Class and Description |
---|---|
class |
TxnDeleteOperation
Transactional delete operation
|
class |
TxnLockAndGetOperation
Transactional lock and get operation.
|
class |
TxnRollbackBackupOperation
An operation to rollback transaction by unlocking the key on key backup owner.
|
class |
TxnRollbackOperation
An operation to rollback transaction by unlocking the key on key owner.
|
class |
TxnSetOperation
An operation to unlock and set (key,value) on the partition .
|
class |
TxnUnlockBackupOperation
An operation to unlock key on the backup owner.
|
class |
TxnUnlockOperation
An operation to unlock key on the partition owner.
|
Modifier and Type | Class and Description |
---|---|
class |
RemoveBackupOperation |
Modifier and Type | Class and Description |
---|---|
class |
TxnPrepareBackupOperation |
class |
TxnPrepareOperation |
Modifier and Type | Class and Description |
---|---|
class |
ReplicatedMapEntryView<K,V> |
Modifier and Type | Class and Description |
---|---|
class |
ReadResultSetImpl<O,E>
A list for the
ReadManyOperation . |
class |
RingbufferContainer<T,E>
The RingbufferContainer is responsible for the functionalities supporting
the underlying ringbuffer structure containing the data.
|
Modifier and Type | Class and Description |
---|---|
class |
ReadManyOperation<O> |
class |
ReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
ScheduledTaskStatisticsImpl |
Modifier and Type | Class and Description |
---|---|
class |
DeregistrationOperation |
class |
RegistrationOperation |
Modifier and Type | Class and Description |
---|---|
class |
MapMergingEntryImpl
Implementation of
SplitBrainMergeTypes.MapMergeTypes . |
Copyright © 2021 Hazelcast, Inc.. All Rights Reserved.