Package | Description |
---|---|
com.hazelcast.cache.impl.journal | |
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cardinality.impl.operations |
This package contains the operations on the
CardinalityEstimator . |
com.hazelcast.client.impl.operations |
Contains client operations
|
com.hazelcast.client.impl.protocol.task.cache |
Client protocol tasks implementations for JCache
|
com.hazelcast.client.impl.protocol.task.map |
Client protocol tasks implementations for map
|
com.hazelcast.collection.impl.collection.operations | |
com.hazelcast.collection.impl.list.operations | |
com.hazelcast.collection.impl.queue.operations |
This package contains the IQueue operations
|
com.hazelcast.collection.impl.txnqueue.operations | |
com.hazelcast.concurrent.atomicreference.operations |
This package contains the operations on the IAtomicReference.
|
com.hazelcast.concurrent.countdownlatch.operations |
This package contains the operations on the ICountDownLatch.
|
com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
com.hazelcast.concurrent.semaphore.operations |
This package contains the operations on the ISemaphore.
|
com.hazelcast.cp.internal |
Contains implementation of the CP subsystem
|
com.hazelcast.cp.internal.operation |
Contains operations for the Raft Invocation SPI
|
com.hazelcast.cp.internal.operation.integration |
Contains Hazelcast operations that carry out Raft RPCs
|
com.hazelcast.cp.internal.raftop.metadata |
Contains operations that are used in the Metadata CP group
|
com.hazelcast.crdt |
This package contains CRDT (conflict-free replicated data type)
implementations based on the Hazelcast infrastructure.
|
com.hazelcast.crdt.pncounter |
This package contains the PN (Positive-Negative) CRDT counter
implementation.
|
com.hazelcast.crdt.pncounter.operations |
Contains the operations for the
PNCounter member-side
implementation. |
com.hazelcast.durableexecutor.impl.operations |
This package contains operations for the DurableExecutorService.
|
com.hazelcast.internal.cluster.impl.operations |
This package contains operations for the com.hazelcast.cluster.impl package.
|
com.hazelcast.internal.journal |
This package contains supporting classes for data structure specific event journals.
|
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.map.impl.journal | |
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.query | |
com.hazelcast.multimap.impl.operations |
Contains operations for Hazelcast MultiMap module.
|
com.hazelcast.ringbuffer.impl.operations | |
com.hazelcast.scheduledexecutor.impl.operations | |
com.hazelcast.spi |
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
|
com.hazelcast.spi.impl.eventservice.impl.operations |
Contains the operations for the
EventServiceImpl . |
com.hazelcast.spi.impl.operationservice.impl.operations |
Contains the Operations being used by the
OperationServiceImpl . |
com.hazelcast.transaction.impl.operations |
Modifier and Type | Class and Description |
---|---|
class |
CacheEventJournalReadOperation<K,V,T>
Reads from the cache event journal in batches.
|
class |
CacheEventJournalSubscribeOperation
Performs the initial subscription to the cache event journal.
|
Modifier and Type | Class and Description |
---|---|
class |
CacheContainsKeyOperation
Cache contains key operation, determines if the cache contains an entry for the specified key.
|
class |
CacheEntryIteratorOperation
Provides iterator functionality for ICache.
|
class |
CacheGetAllOperation
Gets all keys from the cache.
|
class |
CacheGetConfigOperation
Gets a cache configuration or creates one, if a matching cache config is found in this member's config.
|
class |
CacheGetInvalidationMetaDataOperation |
class |
CacheGetOperation
Cache Get Operation.
|
class |
CacheKeyIteratorOperation
Provides iterator functionality for ICache.
|
class |
CacheSizeOperation
This operation implementation is for calculating the cluster size of a named cache.
|
Modifier and Type | Class and Description |
---|---|
class |
EstimateOperation |
Modifier and Type | Class and Description |
---|---|
class |
ClientReAuthOperation |
class |
GetConnectedClientsOperation |
Modifier and Type | Class and Description |
---|---|
class |
CacheAssignAndGetUuidsOperation |
Modifier and Type | Class and Description |
---|---|
class |
MapAssignAndGetUuidsOperation |
Modifier and Type | Class and Description |
---|---|
class |
CollectionContainsOperation |
class |
CollectionGetAllOperation |
class |
CollectionIsEmptyOperation |
class |
CollectionSizeOperation |
Modifier and Type | Class and Description |
---|---|
class |
ListGetOperation |
class |
ListIndexOfOperation |
class |
ListSubOperation |
Modifier and Type | Class and Description |
---|---|
class |
ContainsOperation
Checks whether contain or not item in the Queue.
|
class |
IsEmptyOperation
check if queue is empty
|
class |
IteratorOperation
Provides iterator functionality for Queue.
|
class |
PeekOperation
Peek operation for Queue.
|
class |
RemainingCapacityOperation
Returns the remaining capacity of the queue based on config max-size
|
class |
SizeOperation
Notify size of the queue.
|
Modifier and Type | Class and Description |
---|---|
class |
TxnPeekOperation
Peek operation for the transactional queue.
|
Modifier and Type | Class and Description |
---|---|
class |
IsNullOperation |
Modifier and Type | Class and Description |
---|---|
class |
AwaitOperation |
class |
GetCountOperation |
Modifier and Type | Class and Description |
---|---|
class |
GetLockCountOperation |
class |
GetRemainingLeaseTimeOperation |
class |
IsLockedOperation |
Modifier and Type | Class and Description |
---|---|
class |
AvailableOperation |
Modifier and Type | Interface and Description |
---|---|
interface |
RaftSystemOperation
Marker interface for all operations used in Raft system.
|
Modifier and Type | Class and Description |
---|---|
class |
ChangeRaftGroupMembershipOp
Replicates a membership change operation to a Raft group.
|
class |
DefaultRaftReplicateOp
The operation used by
RaftInvocationManager to replicate a given
RaftOp to leader of the target Raft group. |
class |
DestroyRaftGroupOp
Replicates a
DestroyRaftGroupCmd to a Raft group. |
class |
RaftQueryOp
The operation that passes a query to leader or a follower of a Raft group.
|
class |
RaftReplicateOp
|
class |
RestartCPMemberOp
Resets CP state of a member and restarts the CP subsystem initialization process.
|
Modifier and Type | Class and Description |
---|---|
class |
AppendFailureResponseOp
Carries a failure response from a Raft follower to a Raft leader
for a
AppendRequest RPC |
class |
AppendRequestOp
Carries a
AppendRequest RPC from a Raft group leader to a follower |
class |
AppendSuccessResponseOp
Carries a success response from a Raft follower to a Raft leader
for a
AppendRequest RPC |
class |
AsyncRaftOp
Base class for operation classes that will carry Raft RPCs between
Raft nodes
|
class |
InstallSnapshotOp
Carries a
InstallSnapshot RPC from a Raft group leader to a follower |
class |
PreVoteRequestOp
Carries a
PreVoteRequest RPC from a Raft candidate to a follower |
class |
PreVoteResponseOp
Carries a
PreVoteResponse from a Raft follower to a candidate |
class |
VoteRequestOp
Carries a
VoteRequest RPC from a Raft candidate to a follower |
class |
VoteResponseOp
Carries a
VoteResponse from a Raft follower to a candidate |
Modifier and Type | Class and Description |
---|---|
class |
CreateRaftNodeOp
On creation of a new Raft group or a membership change in an existing Raft
group, this operation is sent to the new members of the Raft group to
initiate the
RaftNode on the new member. |
class |
DestroyRaftNodesOp
When a Raft group is destroyed, its members terminate their internal
RaftNode instances. |
class |
PublishActiveCPMembersOp
CP members use this operation to broadcast their current active CP member
list to the AP Hazelcast members.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable>
Base class for CRDT replication operations.
|
Modifier and Type | Class and Description |
---|---|
class |
PNCounterReplicationOperation
CRDT replication operation for a
PNCounter . |
Modifier and Type | Class and Description |
---|---|
class |
GetOperation
Query operation to retrieve the current value of the
PNCounter . |
Modifier and Type | Class and Description |
---|---|
class |
RetrieveResultOperation
Used to retrieve the response of an execution with the given sequence
|
Modifier and Type | Interface and Description |
---|---|
interface |
JoinOperation
Marker interface for join and post-join operations.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractJoinOperation |
class |
AuthenticationFailureOp |
class |
AuthorizationOp |
class |
BeforeJoinCheckFailureOp |
class |
CommitClusterStateOp |
class |
ConfigMismatchOp
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated.
|
class |
ExplicitSuspicionOp
An operation which is sent by a member that wants to be explicitly suspected by the target.
|
class |
FetchMembersViewOp
An operation sent by the member that starts mastership claim process to fetch/gather member views of other members.
|
class |
FinalizeJoinOp
Sent by the master to all members to finalize the join operation from a joining/returning node.
|
class |
GroupMismatchOp |
class |
HeartbeatComplaintOp |
class |
HeartbeatOp
A heartbeat sent from one cluster member to another.
|
class |
JoinMastershipClaimOp |
class |
JoinRequestOp |
class |
LockClusterStateOp |
class |
MasterResponseOp
Operation sent by any node to set the master address on the receiver
|
class |
MemberAttributeChangedOp |
class |
MembersUpdateOp |
class |
MergeClustersOp |
class |
OnJoinOp |
class |
PromoteLiteMemberOp
Promotes caller lite member to a normal member.
|
class |
RollbackClusterStateOp |
class |
ShutdownNodeOp |
class |
SplitBrainMergeValidationOp
Validate whether clusters may merge to recover from a split brain, based on configuration & cluster version.
|
class |
TriggerExplicitSuspicionOp
An operation which is sent to trigger
ExplicitSuspicionOp on target member. |
class |
TriggerMemberListPublishOp
Requests member list publish from master node
|
class |
WhoisMasterOp |
Modifier and Type | Class and Description |
---|---|
class |
EventJournalReadOperation<T,J>
Reads from the map event journal in batches.
|
Modifier and Type | Interface and Description |
---|---|
interface |
MigrationCycleOperation |
Modifier and Type | Class and Description |
---|---|
class |
AssignPartitions
Sent from non-master nodes to the master to initialize the partition assignment.
|
class |
FetchPartitionStateOperation
Operation sent by the master to the cluster members to fetch their partition state.
|
class |
FinalizeMigrationOperation
Invoked locally on the source or destination of the migration to finalize the migration.
|
class |
HasOngoingMigration |
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 |
PartitionStateVersionCheckOperation
Sent from the master to check the partition table state version on target member.
|
class |
PromotionCommitOperation
Used for committing a promotion on destination.
|
class |
PublishCompletedMigrationsOperation
Sent by master member to other cluster members to publish completed migrations
and the new partition state version.
|
class |
SafeStateCheckOperation
Checks whether a node is safe or not.
|
class |
ShutdownRequestOperation |
class |
ShutdownResponseOperation |
Modifier and Type | Class and Description |
---|---|
class |
MapEventJournalReadOperation<K,V,T>
Reads from the map event journal in batches.
|
class |
MapEventJournalSubscribeOperation
Performs the initial subscription to the map event journal.
|
Modifier and Type | Class and Description |
---|---|
class |
AwaitMapFlushOperation
IMap.flush() call waits the end of flush by using this operation. |
class |
ContainsKeyOperation |
class |
ContainsValueOperation |
class |
GetEntryViewOperation |
class |
IsKeyLoadFinishedOperation
Returns if the key loading and dispatching has finished on this partition
|
class |
IsPartitionLoadedOperation |
class |
MapFetchEntriesOperation
Operation for fetching a chunk of entries from a single
IMap partition. |
class |
MapFetchKeysOperation
Operation for fetching a chunk of keys from a single
IMap partition. |
class |
MapFetchWithQueryOperation
Fetches by query a batch of
fetchSize items from a single partition ID for a map. |
class |
MapGetInvalidationMetaDataOperation |
class |
MapIsEmptyOperation |
class |
MapPartitionDestroyOperation
Operation to destroy the map data on the partition thread
|
class |
MapSizeOperation |
class |
NotifyMapFlushOperation
|
class |
ReadonlyKeyBasedMapOperation
Abstract
MapOperation that serves as based for readonly operations. |
class |
TriggerLoadIfNeededOperation
Triggers key loading on member with
MapKeyLoader.Role.SENDER
or MapKeyLoader.Role.SENDER_BACKUP key
loader role if keys have not yet been loaded. |
Modifier and Type | Class and Description |
---|---|
class |
QueryOperation |
class |
QueryPartitionOperation |
Modifier and Type | Class and Description |
---|---|
class |
ContainsEntryOperation |
class |
CountOperation |
class |
EntrySetOperation |
class |
GetAllOperation |
class |
KeySetOperation |
class |
ValuesOperation |
Modifier and Type | Class and Description |
---|---|
class |
GenericOperation
Ring buffer operations which don't need to send any parameters and which can be determined by only sending the operation
type which is a byte of information.
|
class |
ReadManyOperation<O> |
class |
ReadOneOperation |
Modifier and Type | Class and Description |
---|---|
class |
GetAllScheduledOnMemberOperation |
class |
GetAllScheduledOnPartitionOperation |
class |
GetDelayOperation |
class |
GetResultOperation<V> |
class |
GetStatisticsOperation |
class |
IsCanceledOperation |
class |
IsDoneOperation |
Modifier and Type | Interface and Description |
---|---|
interface |
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Modifier and Type | Class and Description |
---|---|
class |
DeregistrationOperation |
class |
RegistrationOperation |
class |
SendEventOperation
An operation for sending a event to a remote subscriber (not on this node).
|
Modifier and Type | Class and Description |
---|---|
class |
Backup |
Modifier and Type | Class and Description |
---|---|
class |
CreateAllowedDuringPassiveStateTxBackupLogOperation |
class |
PurgeAllowedDuringPassiveStateTxBackupLogOperation |
class |
ReplicateAllowedDuringPassiveStateTxBackupLogOperation |
class |
RollbackAllowedDuringPassiveStateTxBackupLogOperation |
Copyright © 2019 Hazelcast, Inc.. All Rights Reserved.