| Package | Description |
|---|---|
| com.hazelcast.ascii.memcache |
This package contains MemoryCache functionality for Hazelcast.
|
| com.hazelcast.ascii.rest |
This package contains Reset functionality for Hazelcast.
|
| com.hazelcast.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
| com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
Cache Operations
|
| com.hazelcast.cache.impl.record |
Hazelcast JSR-107 aka JCache implementation
Internal record store
|
| com.hazelcast.client.console |
This package contains ClientConsoleApp
|
| com.hazelcast.client.impl.client |
This contains the Requests and other DTO's exchanged between client/server
|
| com.hazelcast.client.impl.operations |
Contains client operations
|
| com.hazelcast.cluster |
This package contains the cluster functionality.
|
| com.hazelcast.cluster.client |
This package contains the client 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.collection.txn |
This package contains the Transaction behavior for the Collections.
|
| 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 |
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the CountDownLatch. |
| com.hazelcast.concurrent.countdownlatch.operations |
This package contains the operations on the ICountDownLatch.
|
| com.hazelcast.concurrent.lock | |
| com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
| com.hazelcast.concurrent.semaphore |
This package contains ISemaphore functionality for Hazelcast.
The ISemaphore is the distributed version of the Semaphore. |
| com.hazelcast.concurrent.semaphore.operations |
This package contains the operations on the ISemaphore.
|
| com.hazelcast.config |
Provides classes for configuring HazelcastInstance.
|
| com.hazelcast.console |
This package contains classes related to ConsoleApp
|
| com.hazelcast.core |
Provides core API interfaces/classes.
|
| 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.hibernate |
Contains interfaces/classes related to Hibernate.
|
| com.hazelcast.hibernate.local |
Provides local classes for Hibernate.
|
| com.hazelcast.instance |
This package contains Hazelcast Instance functionality.
|
| com.hazelcast.management |
Contains classes to provide data/operation interface for Management Center.
|
| com.hazelcast.management.operation |
Contains operations that are called from Management Center.
|
| com.hazelcast.map |
Contains Hazelcast map module classes.
|
| com.hazelcast.map.merge |
Contains merge policies for
IMap |
| com.hazelcast.map.operation |
Package for map operations.
|
| com.hazelcast.map.record |
Contains record specific classes.
|
| com.hazelcast.map.tx |
Contains implementation classes for
TransactionalMap |
| com.hazelcast.map.wan |
Contains wan replication event classes
|
| com.hazelcast.mapreduce.aggregation.impl |
This package contains a set of predefined aggregation implementations
|
| com.hazelcast.mapreduce.impl |
This package contains the default implementation for the map reduce framework
internals.
|
| com.hazelcast.mapreduce.impl.notification |
This package contains all remote node notifications
|
| com.hazelcast.mapreduce.impl.operation |
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
|
| com.hazelcast.monitor |
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
|
| com.hazelcast.monitor.impl |
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc.
|
| com.hazelcast.multimap.impl |
Contains classes for Hazelcast MultiMap module.
|
| 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.nio |
This package contains classes related to New IO
|
| com.hazelcast.nio.serialization |
Contains interfaces/classes related to serialization;
such as serializer interfaces, input/output streams.
|
| com.hazelcast.partition |
Contains the partition logic for Hazelcast.
|
| com.hazelcast.partition.client |
Contains client functionality for partition related information.
|
| com.hazelcast.partition.impl |
Contains the actual implementation of the
InternalPartitionService. |
| com.hazelcast.query |
Contains interfaces/classes related to Hazelcast query and indexing support.
|
| com.hazelcast.query.impl |
Contains the implementation classes of the query functionality.
|
| com.hazelcast.queue.impl |
This package contains the IQueue functionality.
The IQueue is the distributed version of the BlockingQueue. |
| com.hazelcast.queue.impl.tx |
This package contains the Transaction behavior for the IQueue.
|
| com.hazelcast.replicatedmap.impl.messages |
This package contains replication event classes to communicate replications to other nodes
|
| com.hazelcast.replicatedmap.impl.operation |
This package contains some remote operations to execute on remote nodes
|
| com.hazelcast.replicatedmap.impl.record |
This package contains the implementation of the backing data storage for the replicated map implementation
|
| com.hazelcast.spi |
Provides interfaces/classes for Hazelcast SPI.
|
| 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. |
| com.hazelcast.transaction |
Provides interfaces/classes for Hazelcast transaction support.
|
| com.hazelcast.transaction.impl |
Provides implementation for Hazelcast transaction support.
|
| com.hazelcast.util |
This package contains classes to support the inner workings of Hazelcast
as well as some backports of newer Java features / data structures to
support older Java versions in a clean and nice way.
|
| com.hazelcast.wan |
This package contains the WAN replication API
|
| com.hazelcast.web |
Provides Hazelcast-based session replication.
|
| Modifier and Type | Class and Description |
|---|---|
class |
MemcacheEntry |
| Modifier and Type | Class and Description |
|---|---|
class |
RestValue |
| Modifier and Type | Interface and Description |
|---|---|
interface |
CacheEventData
Cache event data object used in publish - dispatch
|
| Modifier and Type | Class and Description |
|---|---|
class |
CacheClearResponse
Provides the response service for
CacheClearOperation |
class |
CacheEventDataImpl |
class |
CacheEventSet |
class |
CacheKeyIteratorResult
Result of the
CacheKeyIteratorOperation |
class |
CacheStatisticsImpl
Some statistics of a
ICache
Statistics accumulated in this data object is published through MxBean |
class |
HazelcastExpiryPolicy
Custom Expiry Policy helper class for general usage
|
| 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 |
CacheClearOperationFactory
Factory for Clear Operation
|
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 |
CacheGetAllOperationFactory
Provides factory for
CacheGetAllOperation |
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 |
CacheLoadAllOperationFactory
Provides factory for
CacheLoadAllOperation |
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
|
class |
CacheSizeOperationFactory
Factory for CacheSizeOperation
|
| Modifier and Type | Interface and Description |
|---|---|
interface |
CacheRecord<V>
Record of the
ICacheRecordStore |
| Modifier and Type | Class and Description |
|---|---|
class |
CacheObjectRecord
Object format is
CacheRecord |
| Modifier and Type | Class and Description |
|---|---|
static class |
ClientConsoleApp.Echo
Echoes to screen
|
| Modifier and Type | Class and Description |
|---|---|
class |
ClientResponse |
| Modifier and Type | Class and Description |
|---|---|
class |
ClientDisconnectionOperation |
class |
ClientReAuthOperation |
class |
OperationFactoryWrapper |
class |
PostJoinClientOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
AuthenticationFailureOperation |
class |
AuthorizationOperation |
class |
BindOperation |
class |
ConfigCheck
Contains enough information about Hazelcast Config, to do a validation check so that clusters with different configurations
don't join.
|
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 |
JoinMessage |
class |
JoinRequest |
class |
JoinRequestOperation |
class |
MasterClaimOperation |
class |
MasterConfirmationOperation |
class |
MasterDiscoveryOperation |
class |
MemberAttributeChangedOperation |
class |
MemberInfo |
class |
MemberInfoUpdateOperation |
class |
MemberRemoveOperation |
class |
MergeClustersOperation |
class |
PostJoinOperation |
class |
PrepareMergeOperation |
class |
SetMasterOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
ClientMembershipEvent |
class |
MemberAttributeChange |
| Modifier and Type | Class and Description |
|---|---|
class |
CollectionAddAllBackupOperation |
class |
CollectionAddAllOperation |
class |
CollectionAddBackupOperation |
class |
CollectionAddOperation |
class |
CollectionBackupAwareOperation |
class |
CollectionClearBackupOperation |
class |
CollectionClearOperation |
class |
CollectionCompareAndRemoveOperation |
class |
CollectionContainer |
class |
CollectionContainsOperation |
class |
CollectionEvent |
class |
CollectionEventFilter |
class |
CollectionGetAllOperation |
class |
CollectionIsEmptyOperation |
class |
CollectionItem |
class |
CollectionOperation |
class |
CollectionRemoveBackupOperation |
class |
CollectionRemoveOperation |
class |
CollectionReplicationOperation |
class |
CollectionSizeOperation |
class |
CollectionTransactionRollbackOperation |
class |
TxCollectionItem |
| Modifier and Type | Class and Description |
|---|---|
class |
ListAddAllOperation |
class |
ListAddOperation |
class |
ListContainer |
class |
ListGetOperation |
class |
ListIndexOfOperation |
class |
ListRemoveOperation |
class |
ListReplicationOperation |
class |
ListSetBackupOperation |
class |
ListSetOperation |
class |
ListSubOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
SetContainer |
class |
SetReplicationOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
CollectionPrepareBackupOperation |
class |
CollectionPrepareOperation |
class |
CollectionReserveAddOperation |
class |
CollectionReserveRemoveOperation |
class |
CollectionRollbackBackupOperation |
class |
CollectionRollbackOperation |
class |
CollectionTransactionLog |
class |
CollectionTxnAddBackupOperation |
class |
CollectionTxnAddOperation |
class |
CollectionTxnRemoveBackupOperation |
class |
CollectionTxnRemoveOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
AddAndGetOperation |
class |
AddBackupOperation |
class |
AtomicLongBackupAwareOperation |
class |
AtomicLongBaseOperation |
class |
AtomicLongReplicationOperation |
class |
GetAndAddOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
AbstractAlterOperation |
class |
AlterAndGetOperation |
class |
AlterOperation |
class |
ApplyOperation |
class |
AtomicReferenceBackupAwareOperation |
class |
AtomicReferenceBaseOperation |
class |
AtomicReferenceReplicationOperation |
class |
CompareAndSetOperation |
class |
GetAndAlterOperation |
class |
GetAndSetOperation |
class |
IsNullOperation |
class |
SetAndGetOperation |
class |
SetBackupOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
CountDownLatchInfo |
| Modifier and Type | Class and Description |
|---|---|
class |
AwaitOperation |
class |
CountDownLatchBackupOperation |
class |
CountDownLatchReplicationOperation |
class |
CountDownOperation |
class |
GetCountOperation |
class |
SetCountOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
InternalLockNamespace |
class |
LockStoreImpl |
| Modifier and Type | Class and Description |
|---|---|
class |
AwaitBackupOperation |
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 |
Permit |
| Modifier and Type | Class and Description |
|---|---|
class |
AcquireBackupOperation |
class |
AcquireOperation |
class |
AvailableOperation |
class |
DeadMemberBackupOperation |
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 |
CacheConfig<K,V>
Contains all the configuration for the
ICache |
class |
CacheConfigReadOnly<K,V>
Contains the configuration for an
ICache (read-only). |
class |
NearCacheConfig
Contains configuration for an NearCache.
|
class |
NearCacheConfigReadOnly
Contains configuration for an NearCache(Read-Only).
|
| Modifier and Type | Class and Description |
|---|---|
static class |
ConsoleApp.Echo
Echoes to screen
|
| Modifier and Type | Interface and Description |
|---|---|
interface |
Member
Cluster member interface.
|
| Modifier and Type | Class and Description |
|---|---|
class |
MemberAttributeEvent |
class |
MigrationEvent
An event fired when a partition migration starts, completes or fails.
|
class |
PartitionAwareKey<K,P>
A
PartitionAware key. |
| Modifier and Type | Class and Description |
|---|---|
class |
CallableTaskOperation |
class |
CancellationOperation |
class |
MemberCallableTaskOperation |
class |
RunnableAdapter<V> |
class |
ShutdownOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
VersionAwareMapMergePolicy
A merge policy implementation to handle split brain remerges based on the timestamps stored in
the values.
|
| Modifier and Type | Class and Description |
|---|---|
class |
Invalidation
An invalidation messages
|
class |
Timestamp
Hazelcast compatible implementation of a timestamp for internal eviction
|
| Modifier and Type | Class and Description |
|---|---|
class |
MemberImpl |
| Modifier and Type | Class and Description |
|---|---|
class |
MapConfigAdapter
Serializable adapter for
MapConfig |
| Modifier and Type | Class and Description |
|---|---|
class |
GetMapConfigOperation
Operation to fetch Map configuration.
|
class |
ScriptExecutorOperation
Operation to execute script on the node.
|
class |
ThreadDumpOperation
Operation for generating thread dumps.
|
class |
UpdateManagementCenterUrlOperation
Operation to update Management Center URL configured on the node.
|
class |
UpdateMapConfigOperation
Operation to update map configuration from Management Center.
|
| Modifier and Type | Interface and Description |
|---|---|
interface |
EventData
General contract for map event data.
|
| Modifier and Type | Class and Description |
|---|---|
class |
EntryEventData
An entry's event data.
|
class |
EntryEventFilter |
class |
MapEntrySet |
class |
MapEventData
Map wide event's data.
|
class |
MapKeySet |
class |
MapValueCollection |
class |
QueryEventFilter |
class |
QueryResult |
class |
SimpleEntryView<K,V>
SimpleEntryView is an implementation of
EntryView and also it is writable. |
| Modifier and Type | Interface and Description |
|---|---|
interface |
MapMergePolicy
A policy for merging maps after a splitbrain was detected and the different network partitions need
to be merged.
|
| Modifier and Type | Class and Description |
|---|---|
class |
HigherHitsMapMergePolicy
HigherHitsMapMergePolicy causes the merging entry to be merged from source to destination map
if source entry has more hits than the destination one.
|
class |
LatestUpdateMapMergePolicy
LatestUpdateMapMergePolicy causes the merging entry to be merged from source to destination map
if source entry has updated more recently than the destination entry.
|
class |
PassThroughMergePolicy
PassThroughMergePolicy causes the merging entry to be merged from source to destination map
unless merging entry is null.
|
class |
PutIfAbsentMapMergePolicy
PutIfAbsentMapMergePolicy causes the merging entry to be merged from source to destination map
if it does not exist in the destination map.
|
| Modifier and Type | Class and Description |
|---|---|
class |
RecordInfo
Record info.
|
class |
RecordReplicationInfo |
class |
RecordStatistics
TODO empty statistics.
|
| Modifier and Type | Class and Description |
|---|---|
class |
MapTransactionLog
Represents an operation on the map in the transaction log.
|
class |
TxnDeleteOperation
Transactional delete operation
|
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.
|
class |
VersionedValue
Wrapper for
Data value objects with version information. |
| Modifier and Type | Class and Description |
|---|---|
class |
MapReplicationRemove |
class |
MapReplicationUpdate |
| Modifier and Type | Class and Description |
|---|---|
class |
AcceptAllSupplier<KeyIn,ValueIn,ValueOut>
A standard implementation of the
Supplier
interface which accepts all input values and may apply a given
PropertyExtractor on those. |
class |
AvgTuple<F,S>
Internal tuple type for average calculations, used to transmit data between
Combiner and Reducer implementations.
|
class |
KeyPredicateSupplier<KeyIn,ValueIn,ValueOut>
The default supplier for
KeyPredicates, used
to filter and optionally transform data (using the given
Supplier). |
class |
PredicateSupplier<KeyIn,ValueIn,ValueOut>
|
class |
SetAdapter<E>
A simple adapter class to serialize values of a
Set using
Hazelcast serialization support. |
| Modifier and Type | Class and Description |
|---|---|
class |
CombinerResultList<E>
|
class |
HashMapAdapter<K,V>
Simple HashMap adapter class to implement DataSerializable serialization semantics
to not loose hands on serialization while sending intermediate results.
|
class |
ListKeyValueSource<V>
This
KeyValueSource implementation is used in
KeyValueSource.fromList(com.hazelcast.core.IList) to generate a default
implementation based on a Hazelcast IList. |
class |
MapKeyValueSource<K,V>
This
KeyValueSource implementation is used in
KeyValueSource.fromMap(com.hazelcast.core.IMap) to generate a default
implementation based on a Hazelcast IMap. |
class |
MultiMapKeyValueSource<K,V>
This
KeyValueSource implementation is used in
KeyValueSource.fromMultiMap(com.hazelcast.core.MultiMap) to generate a default
implementation based on a Hazelcast MultiMap. |
class |
SetKeyValueSource<V>
This
KeyValueSource implementation is used in
KeyValueSource.fromSet(com.hazelcast.core.ISet) to generate a default
implementation based on a Hazelcast ISet. |
| Modifier and Type | Class and Description |
|---|---|
class |
IntermediateChunkNotification<KeyOut,Value>
Notification that is fired every time the chunk limit is reached and is send to the reducers
|
class |
LastChunkNotification<KeyOut,Value>
This notification is used to notify the reducer that this chunk is the last chunk of the
defined partitionId.
|
class |
MapReduceNotification
Base class for all map reduce framework notifications
|
class |
MemberAwareMapReduceNotification
Base class for all notifications based on a member
|
class |
ReducingFinishedNotification
This notification class is used to signal the
JobSupervisor
owner node that a reducer has finished the reducing step for the defined partitionId. |
| 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 |
GetResultOperationFactory
This class is used to create
GetResultOperation
instances.In difference to other implementations of OperationFactory this class
is never ever serialized and the DataSerializable methods GetResultOperationFactory.readData(com.hazelcast.nio.ObjectDataInput)
and GetResultOperationFactory.writeData(com.hazelcast.nio.ObjectDataOutput) throw UnsupportedOperationExceptions. |
class |
KeysAssignmentOperation
This operation is used to request assignment for keys on the job owners node.
|
class |
KeysAssignmentResult
This class is used to store assignment results in
KeysAssignmentOperation
executions. |
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 |
RequestPartitionResult
This class is used to store the requested result of all kinds of processing operations.
By default it holds a basic result state and maybe the partitionId it was operated otherwise it's value is defined as -1 |
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 | Interface and Description |
|---|---|
interface |
LocalCacheStats
Local cache statistics interface to be used
by
MemberState implementations. |
interface |
LocalExecutorStats |
interface |
LocalInstanceStats |
interface |
LocalMapStats
Local map statistics.
|
interface |
LocalMultiMapStats |
interface |
LocalQueueStats
Local queue statistics.
|
interface |
LocalReplicatedMapStats |
interface |
LocalTopicStats |
interface |
NearCacheStats |
| Modifier and Type | Class and Description |
|---|---|
class |
LocalCacheStatsImpl
Default implementation of
LocalCacheStats
This class just provides serialization/deserialization methods to be used in
MemberState implementation while sending/receiving statistics to/from
Management center. |
class |
LocalExecutorStatsImpl |
class |
LocalMapStatsImpl
Default implementation of
LocalMapStats |
class |
LocalMultiMapStatsImpl |
class |
LocalQueueStatsImpl |
class |
LocalReplicatedMapStatsImpl
This class collects statistics about the replication map usage for management center and is
able to transform those between wire format and instance view
|
class |
LocalTopicStatsImpl |
class |
NearCacheStatsImpl |
| Modifier and Type | Class and Description |
|---|---|
class |
MultiMapEventFilter |
class |
MultiMapMigrationOperation |
class |
MultiMapRecord |
| Modifier and Type | Class and Description |
|---|---|
class |
ContainsEntryOperation |
class |
CountOperation |
class |
EntrySetOperation |
class |
EntrySetResponse |
class |
GetAllOperation |
class |
KeySetOperation |
class |
MultiMapBackupAwareOperation |
class |
MultiMapKeyBasedOperation |
class |
MultiMapOperation |
class |
MultiMapOperationFactory |
class |
MultiMapResponse |
class |
PutBackupOperation |
class |
PutOperation |
class |
RemoveAllBackupOperation |
class |
RemoveAllOperation |
class |
ValuesOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
MultiMapTransactionLog |
class |
TxnCommitBackupOperation |
class |
TxnCommitOperation |
class |
TxnGenerateRecordIdOperation |
class |
TxnLockAndGetOperation |
class |
TxnPutBackupOperation |
class |
TxnPutOperation |
class |
TxnRemoveAllBackupOperation |
class |
TxnRemoveAllOperation |
class |
TxnRemoveBackupOperation |
class |
TxnRemoveOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
Address
Represents an address of a member in the cluster.
|
| Modifier and Type | Interface and Description |
|---|---|
interface |
ClassDefinition
ClassDefinition defines a class schema for Portable classes.
|
interface |
FieldDefinition
FieldDefinition defines name, type, index of a field
|
interface |
IdentifiedDataSerializable
IdentifiedDataSerializable is an extension to
DataSerializable
to avoid reflection during de-serialization. |
| Modifier and Type | Class and Description |
|---|---|
class |
BinaryClassDefinitionProxy |
class |
Data |
| Modifier and Type | Class and Description |
|---|---|
class |
MigrationInfo |
class |
PartitionRuntimeState |
| Modifier and Type | Class and Description |
|---|---|
class |
PartitionsResponse |
| Modifier and Type | Class and Description |
|---|---|
class |
AssignPartitions |
class |
BaseMigrationOperation |
class |
CheckReplicaVersion |
class |
HasOngoingMigration |
class |
IsReplicaVersionSync
Queries if replica version is sync between partitions.
|
class |
MigrationOperation |
class |
MigrationRequestOperation |
class |
PartitionStateOperation |
class |
ReplicaSyncRequest |
class |
ReplicaSyncResponse |
class |
ReplicaSyncRetryResponse |
class |
SafeStateCheckOperation
Checks whether a node is safe or not.
|
| Modifier and Type | Class and Description |
|---|---|
class |
PagingPredicate
This class is a special Predicate which helps to get a page-by-page result of a query
Can be constructed with a page-size, an inner predicate for filtering, A comparator for sorting \
This class is not thread-safe and stateless.
|
class |
PredicateBuilder
This class provides functionality to build predicate.
|
static class |
Predicates.AbstractPredicate
Provides some functionality for some predicates
such as Between, In.
|
static class |
Predicates.AndPredicate
And Predicate
|
static class |
Predicates.BetweenPredicate
Between Predicate
|
static class |
Predicates.EqualPredicate
Equal Predicate
|
static class |
Predicates.GreaterLessPredicate
Greater Less Predicate
|
static class |
Predicates.ILikePredicate
Ilike Predicate
|
static class |
Predicates.InPredicate
In Predicate
|
static class |
Predicates.LikePredicate
Like Predicate
|
static class |
Predicates.NotEqualPredicate
Not Equal Predicate
|
static class |
Predicates.NotPredicate
Not Predicate
|
static class |
Predicates.OrPredicate
Or Predicate
|
static class |
Predicates.RegexPredicate
Regex Predicate
|
class |
SqlPredicate
This class contains methods related to conversion of sql query to predicate.
|
class |
TruePredicate
A
Predicate which always returns true. |
| Modifier and Type | Class and Description |
|---|---|
class |
QueryResultEntryImpl
Multiple result set for Predicates
|
| Modifier and Type | Class and Description |
|---|---|
class |
AddAllBackupOperation
Provides backup functionality for
AddAllOperation |
class |
AddAllOperation
Add collection items to the Queue.
|
class |
CheckAndEvictOperation
Provides eviction functionality for Operations of Queue.
|
class |
ClearBackupOperation
Store items' id as set when ClearOperation run.
|
class |
ClearOperation
Clears items stored by Queue.
|
class |
CompareAndRemoveBackupOperation
This class triggers backup method for items' id.
|
class |
CompareAndRemoveOperation
This class triggers iterator and if find same item in the Queue, remove this item.
|
class |
ContainsOperation
Checks whether contain or not item in the Queue.
|
class |
DrainBackupOperation
This class stores items' id when DrainOperation run.
|
class |
DrainOperation
This class drain items according to drain condition.
|
class |
IsEmptyOperation
check if queue is empty
|
class |
IteratorOperation
Provides iterator functionality for Queue.
|
class |
OfferBackupOperation
Backup items during offer operation.
|
class |
OfferOperation
Contains offer operation for the Queue.
|
class |
PeekOperation
Peek operation for Queue.
|
class |
PollBackupOperation
Backup items during pool operation.
|
class |
PollOperation
Pool operation for Queue.
|
class |
QueueBackupAwareOperation
This abstract class contains important methods for all Queue operations.
|
class |
QueueContainer
This class contains methods be notable for the Queue.
|
class |
QueueEvent
Used for queue-wide events.
|
class |
QueueEventFilter
Provides the filtering functionality for Queue events.
|
class |
QueueItem
Queue Item.
|
class |
QueueOperation
This class contains methods for Queue operations
such as
AddAllOperation. |
class |
QueueReplicationOperation
Replication operation for the Queue.
|
class |
RemoveBackupOperation
Remove backup of the Queue item.
|
class |
RemoveOperation
Remove operation for the Queue.
|
class |
SizeOperation
Notify size of the queue.
|
class |
TxQueueItem
Transactional Queue Item.
|
| Modifier and Type | Class and Description |
|---|---|
class |
QueueTransactionLog
This class contains Transaction log for the Queue.
|
class |
QueueTransactionRollbackOperation
Transaction Rollback Operation for the Queue.
|
class |
TxnOfferBackupOperation
Provides backup operation during transactional offer operation.
|
class |
TxnOfferOperation
Offer operation for the Transactional Queue.
|
class |
TxnPeekOperation
Peek operation for the transactional queue.
|
class |
TxnPollBackupOperation
Provides backup operation during transactional poll operation.
|
class |
TxnPollOperation
Poll operation for the transactional queue.
|
class |
TxnPrepareBackupOperation
Provides backup operation during transactional prepare operation.
|
class |
TxnPrepareOperation
Prepare operation for the transactional queue.
|
class |
TxnReserveOfferBackupOperation
Reserve offer backup operation for the transactional queue.
|
class |
TxnReserveOfferOperation
Reserve offer operation for the transactional queue.
|
class |
TxnReservePollBackupOperation
Reserve poll backup operation for the transactional queue.
|
class |
TxnReservePollOperation
Reserve poll operation for the transactional queue.
|
class |
TxnRollbackBackupOperation
Provides backup operation during transactional rollback operation.
|
class |
TxnRollbackOperation
Rollback operation for the transactional queue.
|
| Modifier and Type | Class and Description |
|---|---|
class |
MultiReplicationMessage
This replicated message contains multiple replications at once
|
class |
ReplicationMessage<K,V>
This replication message is used for sending over a replication event to another node
|
| Modifier and Type | Class and Description |
|---|---|
class |
AbstractReplicatedMapOperation
Base class for replicated map remote operations
|
class |
ReplicatedMapClearOperation
This operation will execute the remote clear on replicated map if
ReplicatedMap.clear() is called. |
class |
ReplicatedMapInitChunkOperation
Class for requesting an initial chunk of data from another node to pre-provision newly joining members
|
class |
ReplicatedMapPostJoinOperation
The replicated map post join operation to execute on remote nodes
|
static class |
ReplicatedMapPostJoinOperation.MemberMapPair
A mapping for replicated map names and the assigned provisioning member
|
| Modifier and Type | Class and Description |
|---|---|
class |
ReplicatedRecord<K,V>
A ReplicatedRecord is the actual data holding entity.
|
class |
VectorClockTimestamp
A vector clock implementation based on hashcodes of the Hazelcast members UUID to solve conflicts on
replication updates
|
| Modifier and Type | Interface and Description |
|---|---|
interface |
EventRegistration
The result of a Event Registration.
|
interface |
ObjectNamespace
An ObjectNamespace that makes identification of in object within a service possible.
|
interface |
OperationFactory
A Factory for creating
Operation instances. |
| Modifier and Type | Class and Description |
|---|---|
class |
AbstractOperation
Abstract
Operation implementation with some basic methods
implemented. |
class |
DefaultObjectNamespace
Default
ObjectNamespace implementation. |
class |
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
class |
Operation
An operation could be compared the a
Runnable. |
| Modifier and Type | Class and Description |
|---|---|
class |
PublishOperation |
class |
TopicEvent |
| Modifier and Type | Class and Description |
|---|---|
class |
TransactionOptions
Contains the configuration for a Hazelcast transaction.
|
| Modifier and Type | Interface and Description |
|---|---|
interface |
KeyAwareTransactionLog |
interface |
TransactionLog |
| Modifier and Type | Class and Description |
|---|---|
class |
BeginTxBackupOperation |
class |
BroadcastTxRollbackOperation |
class |
PurgeTxBackupOperation |
class |
RecoveredTransaction |
class |
RecoverTxnOperation |
class |
ReplicateTxOperation |
class |
RollbackTxBackupOperation |
class |
SerializableXID |
| Modifier and Type | Class and Description |
|---|---|
class |
QueryResultSet
Collection(Set) class for result of query operations
|
| Modifier and Type | Class and Description |
|---|---|
class |
WanReplicationEvent
Event class used to transmit the actual event object
|
| Modifier and Type | Class and Description |
|---|---|
class |
AbstractWebDataEntryProcessor<T>
A base class for
EntryProcessors which will use the web data serializer. |
class |
AddSessionEntryProcessor
Sets the initial reference count to 1.
|
class |
DestroySessionEntryProcessor
Decrements the reference count for a session, returning
Boolean.TRUE or Boolean.FALSE to
indicate whether the reference count has reached zero. |
class |
InvalidateSessionAttributesEntryProcessor
Invalidates all attributes for a
destroyed session, removing them
from the clustered map. |
class |
ReferenceSessionEntryProcessor
Increments the reference count, returning
Boolean.FALSE if the entry does not exist and
Boolean.TRUE otherwise. |
class |
SessionAttributePredicate
Filters map entries to retrieve only the ones that belong to a specific session.
|
Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.