Package | Description |
---|---|
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
Cache Operations
|
com.hazelcast.client.impl.operations |
Contains client operations
|
com.hazelcast.cluster |
This package contains the cluster functionality.
|
com.hazelcast.collection |
This package contains classes related to Collections (IList,ISet etc..)
|
com.hazelcast.collection.list |
This package contains IList functionality for Hazelcast.
|
com.hazelcast.collection.set |
This package contains ISet functionality for Hazelcast.
|
com.hazelcast.concurrent.atomiclong.operations |
This package contains the operations on the IAtomicLong.
|
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.executor.impl |
This package contains IExecutorService functionality for Hazelcast.
The IExecutorService extends the ExecutorService and provides all kinds
of additional methods related to distributed systems. |
com.hazelcast.map.operation |
Package for map operations.
|
com.hazelcast.mapreduce.impl.operation |
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
|
com.hazelcast.multimap.impl |
Contains classes for Hazelcast MultiMap module.
|
com.hazelcast.partition.impl |
Contains the actual implementation of the
InternalPartitionService . |
com.hazelcast.queue.impl |
This package contains the IQueue functionality.
The IQueue is the distributed version of the BlockingQueue . |
com.hazelcast.replicatedmap.impl.operation |
This package contains some remote operations to execute on remote nodes
|
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.topic.impl |
This package contains ITopic functionality for Hazelcast.
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMutatingCacheOperation
Base modifying cache operation, this operation publishes COMPLETE events
|
class |
CacheClearBackupOperation
Store keys as set when ClearOperation run.
|
class |
CacheClearOperation
Cache Clear, remove all operation with or without a set of keys provided
|
class |
CacheContainsKeyOperation
Cache ContainsKey Operation
|
class |
CacheCreateConfigOperation
Cache CreateConfig Operation
|
class |
CacheDestroyOperation
Cache CreateConfig Operation
|
class |
CacheEntryProcessorOperation
Operation of the Cache Entry Processor.
|
class |
CacheGetAllOperation
Get all keys from Cache.
|
class |
CacheGetAndRemoveOperation
Cache GetAndRemove Operation
|
class |
CacheGetAndReplaceOperation
Cache GetAndReplace Operation
|
class |
CacheGetConfigOperation
Cache GetConfig Operation
|
class |
CacheGetOperation
Cache Get Operation
|
class |
CacheKeyIteratorOperation
Provides iterator functionality for ICache.
|
class |
CacheListenerRegistrationOperation
Provides Listener Registration Service.
|
class |
CacheLoadAllOperation
Triggers cache store load of all given keys.
|
class |
CacheManagementConfigOperation
Cache ManagementConfig Operation
|
class |
CachePutAllBackupOperation
Cache PutAllBackup Operation
|
class |
CachePutBackupOperation
Cache PutBackup Operation
|
class |
CachePutIfAbsentOperation
Cache PutIfAbsent Operation
|
class |
CachePutOperation
Cache Put operation
|
class |
CacheRemoveBackupOperation
Cache RemoveBackup Operation
|
class |
CacheRemoveOperation
Cache Remove Operation
|
class |
CacheReplaceOperation
Cache Replace Operation
|
class |
CacheReplicationOperation
Cache Replication Operation for migration
|
class |
CacheSizeOperation
Cache Size Operation
|
Modifier and Type | Class and Description |
---|---|
class |
ClientDisconnectionOperation |
class |
ClientReAuthOperation |
class |
PostJoinClientOperation |
Modifier and Type | Class and Description |
---|---|
class |
AuthenticationFailureOperation |
class |
AuthorizationOperation |
class |
BindOperation |
class |
ConfigMismatchOperation
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated.
|
class |
FinalizeJoinOperation |
class |
GroupMismatchOperation |
class |
HeartbeatOperation |
class |
JoinCheckOperation |
class |
JoinRequestOperation |
class |
MasterClaimOperation |
class |
MasterConfirmationOperation |
class |
MasterDiscoveryOperation |
class |
MemberAttributeChangedOperation |
class |
MemberInfoUpdateOperation |
class |
MemberRemoveOperation |
class |
MergeClustersOperation |
class |
PostJoinOperation |
class |
PrepareMergeOperation |
class |
SetMasterOperation |
Modifier and Type | Class and Description |
---|---|
class |
CollectionReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
ListReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
SetReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AtomicLongReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AtomicReferenceReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
CountDownLatchBackupOperation |
class |
CountDownLatchReplicationOperation |
class |
CountDownOperation |
class |
GetCountOperation |
class |
SetCountOperation |
Modifier and Type | Class and Description |
---|---|
class |
AwaitBackupOperation |
class |
AwaitOperation |
class |
BeforeAwaitBackupOperation |
class |
BeforeAwaitOperation |
class |
GetLockCountOperation |
class |
GetRemainingLeaseTimeOperation |
class |
IsLockedOperation |
class |
LocalLockCleanupOperation |
class |
LockBackupOperation |
class |
LockOperation |
class |
LockReplicationOperation |
class |
SignalBackupOperation |
class |
SignalOperation |
class |
UnlockBackupOperation |
class |
UnlockIfLeaseExpiredOperation |
class |
UnlockOperation |
Modifier and Type | Class and Description |
---|---|
class |
AcquireBackupOperation |
class |
AcquireOperation |
class |
AvailableOperation |
class |
DeadMemberBackupOperation |
class |
DrainBackupOperation |
class |
DrainOperation |
class |
InitBackupOperation |
class |
InitOperation |
class |
ReduceBackupOperation |
class |
ReduceOperation |
class |
ReleaseBackupOperation |
class |
ReleaseOperation |
class |
SemaphoreBackupAwareOperation |
class |
SemaphoreBackupOperation |
class |
SemaphoreDeadMemberOperation |
class |
SemaphoreOperation |
class |
SemaphoreReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
ShutdownOperation |
Modifier and Type | Class and Description |
---|---|
class |
CancelJobSupervisorOperation
This operation is fired by the jobs owner node to remotely cancel the defined jobId on all nodes.
|
class |
FireNotificationOperation
This operation is used to transport and execute a notification on a remote node since
the current event service is not capable of reliable transmission so this is a fallback
to sync operations which is hopefully only a temporary workaround!
|
class |
GetResultOperation
This operation is used to retrieve results from a remote node
|
class |
KeysAssignmentOperation
This operation is used to request assignment for keys on the job owners node.
|
class |
KeyValueJobOperation<K,V>
This operation is used to prepare a
KeyValueSource based
map reduce operation on all cluster members. |
class |
NotifyRemoteExceptionOperation
This operation is used to inform the job owner of a remote exception
|
class |
PostPonePartitionProcessing
This operation is used to tell the job owner to postpone a mapping phase for the defined
partitionId.
|
class |
ProcessingOperation
This is the base class for all map reduce framework operations, it always contains the name of
the JobTracker and the unique jobId
|
class |
ProcessStatsUpdateOperation
This operation is used to update the process statistics on the owner node
|
class |
RequestMemberIdAssignment
This operation is used to do some kind of partitionId based processing on non partition based implementations
of
KeyValueSource (not implementing PartitionIdAware )
which can happen for custom data sources like distributed filesystems that are up to the end user on how to
manage the distribution. |
class |
RequestPartitionMapping
This operation requests a new partition to process by the requester on the job owning node
|
class |
RequestPartitionProcessed
This operation tells the job owner to mark a partition as fully processed
|
class |
RequestPartitionReducing
This operation tells the job owner to start reducing phase of the defined partition on the first
occurrence of a full emitted chunk
|
class |
StartProcessingJobOperation<K>
This operation is used to start the actual processing after all node prepared to execute the map reduce job
|
Modifier and Type | Class and Description |
---|---|
class |
MultiMapMigrationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AssignPartitions |
class |
BaseMigrationOperation |
class |
HasOngoingMigration |
class |
MigrationOperation |
class |
MigrationRequestOperation |
class |
PartitionStateOperation |
class |
SafeStateCheckOperation
Checks whether a node is safe or not.
|
Modifier and Type | Class and Description |
---|---|
class |
QueueReplicationOperation
Replication operation for the Queue.
|
Modifier and Type | Class and Description |
---|---|
class |
ReplicatedMapClearOperation
This operation will execute the remote clear on replicated map if
ReplicatedMap.clear() is called. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractNamedOperation |
static class |
EventServiceImpl.DeregistrationOperation |
static class |
EventServiceImpl.PostJoinRegistrationOperation |
static class |
EventServiceImpl.RegistrationOperation |
static class |
EventServiceImpl.SendEventOperation |
class |
IsStillExecutingOperation
An operation that checks if another operation is still running.
|
class |
PartitionIteratingOperation |
static class |
ProxyServiceImpl.DistributedObjectDestroyOperation |
static class |
ProxyServiceImpl.PostJoinProxyOperation |
class |
TraceableIsStillExecutingOperation |
Modifier and Type | Class and Description |
---|---|
class |
PublishOperation |
Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.