| Package | Description |
|---|---|
| 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.client.impl.client |
This contains the Requests and other DTO's exchanged between client/server
|
| 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.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.instance |
This package contains Hazelcast Instance functionality.
|
| com.hazelcast.map |
Contains Hazelcast map module classes.
|
| com.hazelcast.map.operation |
Package for map operations.
|
| 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.impl |
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc.
|
| 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.client |
Contains client functionality for partition related information.
|
| 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 |
This package contains the implementation of the replicated map service itself and some connection interfaces only used
internally - No public API!
|
| 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.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.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.web |
Provides Hazelcast-based session replication.
|
| 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 |
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 |
CacheSizeOperation
Cache Size Operation
|
class |
CacheSizeOperationFactory
Factory for CacheSizeOperation
|
| Modifier and Type | Class and Description |
|---|---|
class |
ClientResponse |
| Modifier and Type | Class and Description |
|---|---|
class |
ConfigCheck
Contains enough information about Hazelcast Config, to do a validation check so that clusters with different configurations
don't join.
|
class |
HeartbeatOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
ClientMembershipEvent |
| Modifier and Type | Class and Description |
|---|---|
class |
CollectionAddAllBackupOperation |
class |
CollectionAddAllOperation |
class |
CollectionAddBackupOperation |
class |
CollectionAddOperation |
class |
CollectionBackupAwareOperation |
class |
CollectionClearBackupOperation |
class |
CollectionClearOperation |
class |
CollectionCompareAndRemoveOperation |
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 |
ListGetOperation |
class |
ListIndexOfOperation |
class |
ListRemoveOperation |
class |
ListReplicationOperation |
class |
ListSetBackupOperation |
class |
ListSetOperation |
class |
ListSubOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
SetReplicationOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
CollectionPrepareBackupOperation |
class |
CollectionPrepareOperation |
class |
CollectionReserveAddOperation |
class |
CollectionReserveRemoveOperation |
class |
CollectionRollbackBackupOperation |
class |
CollectionRollbackOperation |
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 |
class |
SetOperation |
| 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 |
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 |
AcquireBackupOperation |
class |
AcquireOperation |
class |
AvailableOperation |
class |
DeadMemberBackupOperation |
class |
InitBackupOperation |
class |
InitOperation |
class |
ReduceBackupOperation |
class |
ReduceOperation |
class |
ReleaseBackupOperation |
class |
ReleaseOperation |
class |
SemaphoreDeadMemberOperation |
class |
SemaphoreReplicationOperation |
| Modifier and Type | Class and Description |
|---|---|
class |
CallableTaskOperation |
class |
MemberCallableTaskOperation |
class |
RunnableAdapter<V> |
| Modifier and Type | Class and Description |
|---|---|
class |
MemberImpl |
| Modifier and Type | Class and Description |
|---|---|
class |
MapEntrySet |
class |
MapKeySet |
class |
MapValueCollection |
class |
SimpleEntryView<K,V>
SimpleEntryView is an implementation of
EntryView and also it is writable. |
| Modifier and Type | Class and Description |
|---|---|
class |
GetOperation |
| 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 |
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 cully 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 | Class and Description |
|---|---|
class |
LocalMapStatsImpl
Default implementation of
LocalMapStats |
class |
LocalMultiMapStatsImpl |
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
|
| Modifier and Type | Class and Description |
|---|---|
class |
ContainsEntryOperation |
class |
CountOperation |
class |
EntrySetOperation |
class |
GetAllOperation |
class |
KeySetOperation |
class |
MultiMapBackupAwareOperation |
class |
MultiMapKeyBasedOperation |
class |
MultiMapOperation |
class |
PutBackupOperation |
class |
PutOperation |
class |
RemoveAllBackupOperation |
class |
RemoveAllOperation |
class |
ValuesOperation |
| Modifier and Type | Class and Description |
|---|---|
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 | Class and Description |
|---|---|
class |
Data |
| Modifier and Type | Method and Description |
|---|---|
IdentifiedDataSerializable |
DataSerializableFactory.create(int typeId)
Creates an IdentifiedDataSerializable instance using given type id
|
IdentifiedDataSerializable |
ArrayDataSerializableFactory.create(int typeId) |
| Modifier and Type | Class and Description |
|---|---|
class |
PartitionsResponse |
| 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 |
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 | Method and Description |
|---|---|
void |
ReplicatedMessageListener.onMessage(IdentifiedDataSerializable message) |
| 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 |
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
|
| 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 | Class and Description |
|---|---|
class |
BinaryOperationFactory |
static class |
EventServiceImpl.EventPacket |
class |
NormalResponse
A NormalResponse is send when an Operation needs to return a value.
|
class |
PartitionIteratingOperation |
static class |
PartitionIteratingOperation.PartitionResponse |
class |
Response
|
class |
SerializableCollection |
| Modifier and Type | Class and Description |
|---|---|
class |
PublishOperation |
class |
TopicEvent |
| Modifier and Type | Class and Description |
|---|---|
class |
QueryResultSet
Collection(Set) class for result of query operations
|
| 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 © 2014 Hazelcast, Inc.. All Rights Reserved.