Package | Description |
---|---|
com.hazelcast.cache |
This package contains the public API extension for Hazelcast JCache,
the Hazelcast implementation of the JSR-107 commonly referred to as JCache.
|
com.hazelcast.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.event |
Event classes to define listenters for JCache other than EntryListener
|
com.hazelcast.cache.impl.merge.entry |
This package contains merge entry internal interfaces and functionality for Hazelcast cache.
|
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.record |
Hazelcast JSR-107 aka JCache implementation
Internal record store
|
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.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.cluster.impl.operations |
This package contains operations for the com.hazelcast.cluster.impl package.
|
com.hazelcast.collection.impl.collection | |
com.hazelcast.collection.impl.collection.operations | |
com.hazelcast.collection.impl.list |
This package contains IList functionality for Hazelcast.
|
com.hazelcast.collection.impl.list.operations | |
com.hazelcast.collection.impl.queue | |
com.hazelcast.collection.impl.queue.operations |
This package contains the IQueue operations
|
com.hazelcast.collection.impl.set |
This package contains ISet functionality for Hazelcast.
|
com.hazelcast.collection.impl.set.operations | |
com.hazelcast.collection.impl.txncollection | |
com.hazelcast.collection.impl.txncollection.operations | |
com.hazelcast.collection.impl.txnqueue | |
com.hazelcast.collection.impl.txnqueue.operations | |
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.executor.impl.operations |
This package contains operations for the IExecutorService.
|
com.hazelcast.hibernate |
Contains interfaces/classes related to Hibernate.
|
com.hazelcast.hibernate.distributed |
Provides distributed class for Hibernate.
|
com.hazelcast.hibernate.local |
Provides local classes for Hibernate.
|
com.hazelcast.hibernate.serialization |
This class contains the Hibernate4 serializer hooks so what we don't
loose handling on serialization while working on hibernate
|
com.hazelcast.instance |
This package contains Hazelcast Instance functionality.
|
com.hazelcast.internal.ascii.memcache |
This package contains MemoryCache functionality for Hazelcast.
|
com.hazelcast.internal.ascii.rest |
This package contains Reset functionality for Hazelcast.
|
com.hazelcast.internal.management.dto |
These contain the DTO object to exchange information with the management center.
|
com.hazelcast.internal.management.operation |
Contains operations that are called from Management Center.
|
com.hazelcast.map.impl |
Contains implementation specific classes of
com.hazelcast.map package. |
com.hazelcast.map.impl.event | |
com.hazelcast.map.impl.nearcache | |
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.query | |
com.hazelcast.map.impl.querycache.event |
This package contains classes for query cache events.
|
com.hazelcast.map.impl.record |
Contains record specific classes.
|
com.hazelcast.map.impl.tx |
Contains implementation classes for
TransactionalMap |
com.hazelcast.map.impl.wan |
Contains wan replication event classes
|
com.hazelcast.map.merge |
Contains merge policies for
IMap |
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.mapreduce.impl.task |
This package contains the base implementation for a standard map reduce job.
|
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.query.impl.predicates | |
com.hazelcast.replicatedmap.impl.operation |
This package contains replicated map operations which are executed 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.ringbuffer.impl |
Contains the
Ringbuffer implementation classes. |
com.hazelcast.ringbuffer.impl.operations | |
com.hazelcast.spi |
Provides interfaces/classes for Hazelcast SPI.
|
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.spi.impl.eventservice.impl |
Contains the code for the
InternalEventService implementation. |
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.spi.impl.operationservice.impl.responses |
Contains the different responses that can be send as a consequence of an Operation invocation.
|
com.hazelcast.spi.impl.proxyservice.impl |
Contains the implementation of the
InternalProxyService . |
com.hazelcast.spi.impl.proxyservice.impl.operations |
Contains the operations for the
ProxyServiceImpl . |
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.topic.impl.reliable | |
com.hazelcast.transaction |
Provides interfaces/classes for Hazelcast transaction support.
|
com.hazelcast.transaction.impl |
Provides implementation for Hazelcast transaction support.
|
com.hazelcast.transaction.impl.operations | |
com.hazelcast.transaction.impl.xa |
Provides implementation for Hazelcast XA transaction support.
|
com.hazelcast.transaction.impl.xa.operations | |
com.hazelcast.wan |
This package contains the WAN replication API
|
com.hazelcast.web |
Provides Hazelcast-based session replication.
|
com.hazelcast.web.entryprocessor |
Provides Entry Processors used in hazelcast-wm
|
Modifier and Type | Class and Description |
---|---|
class |
HazelcastExpiryPolicy
Hazelcast provides overloads of the typical cache operations with a custom
ExpiryPolicy parameter.This class provides a custom implementation of an ExpiryPolicy to
react on all three types of policies:
Create
Access
Update
|
Modifier and Type | Interface and Description |
---|---|
interface |
CacheEventData
Internal event data wrapper used during publishing and dispatching events.
|
Modifier and Type | Class and Description |
---|---|
class |
CacheClearResponse
This class is a simple object wrapper to be used by
CacheClearOperation . |
class |
CacheEventDataImpl
Implementation of
CacheEventData . |
class |
CacheEventSet
Internal Set wrapper of
CacheEventData items used during publishing and dispatching events. |
class |
CacheKeyIteratorResult
Response data object returned by
CacheKeyIteratorOperation . |
class |
CachePartitionEventData |
Modifier and Type | Class and Description |
---|---|
class |
CachePartitionLostEventFilter
Used to filter partition lost listener events
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultCacheEntryView
Default heap based implementation of
CacheEntryView . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMutatingCacheOperation
Base class for all mutable cache operations.
|
class |
CacheBackupEntryProcessorOperation
Operation of the Cache Backup Entry Processor.
|
class |
CacheClearBackupOperation
Backup operation of
CacheClearOperation . |
class |
CacheClearOperation
Cache Clear will clear all internal cache data without sending any event
|
class |
CacheClearOperationFactory
OperationFactory implementation for Clear Operations. |
class |
CacheContainsKeyOperation
Cache contains key operation, determines if the cache contains an entry for the specified key.
|
class |
CacheCreateConfigOperation
Used to create cluster wide cache configuration.
|
class |
CacheDestroyOperation
Destroys the cache on the cluster or on a single node by calling
CacheService#deleteCache(String, boolean, String, boolean) . |
class |
CacheEntryProcessorOperation
Operation of the Cache Entry Processor.
|
class |
CacheGetAllOperation
Gets all keys from the cache.
|
class |
CacheGetAllOperationFactory
Factory implementation 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
Listener can be registered and unregistered by
CacheService . |
class |
CacheLoadAllOperation
Loads all entries of the keys to partition record store
ICacheRecordStore . |
class |
CacheLoadAllOperationFactory
Factory implementation for
CacheLoadAllOperation . |
class |
CacheManagementConfigOperation
Cache ManagementConfig Operation provides enabling/disabling the functionality of management and
statistics mxbeans of the cache.
|
class |
CacheMergeOperation |
class |
CachePutAllBackupOperation
Cache PutAllBackup Operation is the backup operation used by load all operation.
|
class |
CachePutAllOperation |
class |
CachePutBackupOperation
Backup operation for the operation of adding cache entries into record stores.
|
class |
CachePutIfAbsentOperation
Operation implementation for calling
ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int) . |
class |
CachePutOperation
Operation implementation for
ICacheRecordStore.put(Data, Object, ExpiryPolicy, String, int) and
ICacheRecordStore.getAndPut(Data, Object, ExpiryPolicy, String, int) . |
class |
CacheRemoveAllBackupOperation
Backup operation of
CacheRemoveAllOperation . |
class |
CacheRemoveAllOperation
TODO add a proper JavaDoc
|
class |
CacheRemoveAllOperationFactory
OperationFactory implementation for RemoveAll Operations. |
class |
CacheRemoveBackupOperation
Backup operation used by remove operations.
|
class |
CacheRemoveOperation
Operation implementation for cache remove functionality.
|
class |
CacheReplaceOperation
Operator implementation for cache replace functionality.
|
class |
CacheReplicationOperation
Replication operation is the data migration operation of
CacheRecordStore . |
class |
CacheSizeOperation
This operation implementation is for calculating the cluster size of a named cache.
|
class |
CacheSizeOperationFactory
Factory implementation of
CacheSizeOperation . |
class |
PostJoinCacheOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCacheRecord<V>
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 | Class and Description |
---|---|
class |
ClientResponse |
Modifier and Type | Class and Description |
---|---|
class |
ClientDisconnectionOperation |
class |
ClientReAuthOperation |
class |
GetConnectedClientsOperation |
class |
OperationFactoryWrapper |
class |
PostJoinClientOperation |
Modifier and Type | Class and Description |
---|---|
class |
MemberInfo |
Modifier and Type | Class and Description |
---|---|
class |
ClientInitialMembershipEvent |
class |
ClientMembershipEvent |
class |
MemberAttributeChange |
Modifier and Type | Class and Description |
---|---|
class |
BindMessage |
class |
ClusterStateTransactionLogRecord
TransactionLogRecord implementation to be used in
ClusterState transactions. |
class |
ConfigCheck
Contains enough information about Hazelcast Config, to do a validation check so that clusters with different configurations
don't join.
|
class |
JoinMessage |
class |
JoinRequest |
Modifier and Type | Class and Description |
---|---|
class |
AuthenticationFailureOperation |
class |
AuthorizationOperation |
class |
BeforeJoinCheckFailureOperation |
class |
ChangeClusterStateOperation |
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 |
LockClusterStateOperation |
class |
MasterClaimOperation |
class |
MasterConfirmationOperation |
class |
MasterDiscoveryOperation |
class |
MemberAttributeChangedOperation |
class |
MemberInfoUpdateOperation |
class |
MemberRemoveOperation |
class |
MergeClustersOperation |
class |
PostJoinOperation |
class |
RollbackClusterStateOperation |
class |
SetMasterOperation |
class |
ShutdownNodeOperation |
class |
TriggerMemberListPublishOperation
Requests member list publish from master node
|
Modifier and Type | Class and Description |
---|---|
class |
CollectionContainer |
class |
CollectionEvent |
class |
CollectionEventFilter |
class |
CollectionItem |
class |
TxCollectionItem |
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 |
CollectionGetAllOperation |
class |
CollectionIsEmptyOperation |
class |
CollectionOperation |
class |
CollectionRemoveBackupOperation |
class |
CollectionRemoveOperation |
class |
CollectionReplicationOperation |
class |
CollectionSizeOperation |
Modifier and Type | Class and Description |
---|---|
class |
ListContainer |
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 |
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.
|
Modifier and Type | Class and Description |
---|---|
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 |
QueueOperation
This class contains methods for Queue operations
such as
AddAllOperation . |
class |
QueueReplicationOperation
Replication operation for the Queue.
|
class |
RemainingCapacityOperation
Returns the remaining capacity of the queue based on config max-size
|
class |
RemoveBackupOperation
Remove backup of the Queue item.
|
class |
RemoveOperation
Remove operation for the Queue.
|
class |
SizeOperation
Notify size of the queue.
|
Modifier and Type | Class and Description |
---|---|
class |
SetContainer |
Modifier and Type | Class and Description |
---|---|
class |
SetReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
CollectionTransactionLogRecord |
Modifier and Type | Class and Description |
---|---|
class |
CollectionPrepareBackupOperation |
class |
CollectionPrepareOperation |
class |
CollectionReserveAddOperation |
class |
CollectionReserveRemoveOperation |
class |
CollectionRollbackBackupOperation |
class |
CollectionRollbackOperation |
class |
CollectionTransactionRollbackOperation |
class |
CollectionTxnAddBackupOperation |
class |
CollectionTxnAddOperation |
class |
CollectionTxnRemoveBackupOperation |
class |
CollectionTxnRemoveOperation |
Modifier and Type | Class and Description |
---|---|
class |
QueueTransactionLogRecord
This class contains Transaction log for 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 | Class and Description |
---|---|
class |
AddAndGetOperation |
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 |
CountDownLatchContainer |
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 |
BaseLockOperation |
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 |
SemaphoreContainer |
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>
Readonly version of
CacheConfig |
class |
CacheEvictionConfig
Deprecated.
Use
EvictionConfig instead of this |
class |
CacheEvictionConfigReadOnly
Deprecated.
Use
EvictionConfigReadOnly instead of this |
class |
EvictionConfig
Configuration for eviction.
|
class |
EvictionConfigReadOnly
Read only version of
EvictionConfig . |
class |
MaxSizeConfig
Configuration for map's capacity.
|
class |
MaxSizeConfigReadOnly
Contains the configuration for a size of Map.
|
class |
NearCacheConfig
Contains configuration for an NearCache.
|
class |
NearCacheConfigReadOnly
Contains configuration for an NearCache(Read-Only).
|
class |
WanReplicationRef
Configuration for Wan target replication reference
|
class |
WanReplicationRefReadOnly
Configuration for Wan target replication reference(read only)
|
Modifier and Type | Class and Description |
---|---|
class |
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 |
RunnableAdapter<V>
|
Modifier and Type | Class and Description |
---|---|
class |
CallableTaskOperation |
class |
CancellationOperation |
class |
MemberCallableTaskOperation |
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 |
AbstractRegionCacheEntryProcessor
An abstract implementation of
EntryProcessor which acts on a hibernate region cache
IMap |
class |
LockEntryProcessor
A concrete implementation of
EntryProcessor which soft-locks
a region cached entry |
class |
UnlockEntryProcessor
A concrete implementation of
EntryProcessor which unlocks
a soft-locked region cached entry |
class |
UpdateEntryProcessor
A concrete implementation of
EntryProcessor which attempts
to update a region cache entry |
Modifier and Type | Class and Description |
---|---|
class |
Timestamp
Hazelcast compatible implementation of a timestamp for internal eviction
|
Modifier and Type | Class and Description |
---|---|
class |
Expirable
A container class which represents an entry in a region cache which can be marked for expiration
|
class |
ExpiryMarker
An entry which is marked for expiration.
|
class |
Value
A value within a region cache
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMember |
class |
MemberImpl |
Modifier and Type | Class and Description |
---|---|
class |
MemcacheEntry |
Modifier and Type | Class and Description |
---|---|
class |
RestValue |
Modifier and Type | Class and Description |
---|---|
class |
MapConfigDTO
Serializable adapter for
MapConfig |
Modifier and Type | Class and Description |
---|---|
class |
ChangeWanStateOperation
Enables/Disable publishing events to target cluster in WAN Replication
WanReplicationService
on a node. |
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 | Class and Description |
---|---|
class |
EntryEventFilter |
class |
EventListenerFilter
Prevents sending of not requested events to a
MapListener
by filtering events according the implemented MapListener sub-interfaces. |
class |
MapEntries
MapEntries is a collection of
Map.Entry instances. |
class |
MapKeySet |
class |
MapPartitionLostEventFilter |
class |
MapValueCollection |
class |
SimpleEntryView<K,V>
SimpleEntryView is an implementation of
EntryView and also it is writable. |
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 |
MapEventData
Map wide event's data.
|
class |
MapPartitionEventData
Contains the data related to a map partition event
|
Modifier and Type | Class and Description |
---|---|
class |
BatchNearCacheInvalidation |
class |
CleaningNearCacheInvalidation
Used when invalidating client near-caches.
|
class |
Invalidation
Root interface for near-cache invalidation data.
|
class |
SingleNearCacheInvalidation |
Modifier and Type | Class and Description |
---|---|
class |
QueryEventFilter |
class |
QueryOperation |
class |
QueryPartitionOperation |
class |
QueryResult
Contains the result of a query evaluation.
|
class |
QueryResultRow
This interfaces provides methods related to entry of the query result.
|
Modifier and Type | Interface and Description |
---|---|
interface |
QueryCacheEventData
Event data contract which is sent to subscriber side.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultQueryCacheEventData
Default implementation of
QueryCacheEventData which is sent to subscriber. |
Modifier and Type | Interface and Description |
---|---|
interface |
RecordStatistics
Represents statistics of a
Record . |
Modifier and Type | Class and Description |
---|---|
class |
EmptyRecordStatistics
Empty
RecordStatistics implementation which returns zero for all stats. |
class |
RecordInfo
Record info.
|
class |
RecordReplicationInfo |
class |
RecordStatisticsImpl
Statistics of a
Record |
Modifier and Type | Class and Description |
---|---|
class |
MapTransactionLogRecord
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 | 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 |
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
KeyPredicate s, 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 UnsupportedOperationException s. |
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 | Class and Description |
---|---|
class |
JobPartitionStateImpl
This class holds information about the current processing state and the owner of a partition
|
Modifier and Type | Class and Description |
---|---|
class |
MultiMapEventFilter |
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 |
MultiMapMigrationOperation |
class |
MultiMapOperation |
class |
MultiMapOperationFactory |
class |
MultiMapResponse |
class |
PutBackupOperation |
class |
PutOperation |
class |
RemoveAllBackupOperation |
class |
RemoveAllOperation |
class |
ValuesOperation |
Modifier and Type | Class and Description |
---|---|
class |
MultiMapTransactionLogRecord |
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 |
IdentifiedDataSerializable
IdentifiedDataSerializable is an extension to
DataSerializable
to avoid reflection during de-serialization. |
Modifier and Type | Class and Description |
---|---|
class |
InternalPartitionLostEvent
Internal event that is dispatched to @see com.hazelcast.spi.PartitionAwareService#onPartitionLost()
It contains the partition id, number of replicas that is lost and the address of node that detects the partition lost
|
class |
MigrationInfo |
class |
PartitionLostEvent
The event that is fired when a partition lost its owner and all backups.
|
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.
|
class |
PredicateBuilder
This class provides functionality to build 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 |
FalsePredicate
reminder:
when FalsePredicate is going to implement IdentifiedDataSerializable, make sure no new instance
is created, but the INSTANCE is returned.
|
static class |
IndexImpl.NullObject |
Modifier and Type | Class and Description |
---|---|
class |
AbstractIndexAwarePredicate |
class |
AbstractPredicate
Provides base features for predicates, such as extraction and convertion of the attribute's value.
|
class |
AndPredicate
And Predicate
|
class |
BetweenPredicate
Between Predicate
|
class |
EqualPredicate
Equal Predicate
|
class |
GreaterLessPredicate
Greater Less Predicate
|
class |
ILikePredicate
Ilike Predicate
|
class |
InPredicate
In Predicate
|
class |
InstanceOfPredicate
Predicate version of `instaceof` operator from Java.
|
class |
LikePredicate
Like Predicate
|
class |
NotEqualPredicate
Not Equal Predicate
|
class |
NotPredicate
Not Predicate
|
class |
OrPredicate
Or Predicate
|
class |
RegexPredicate
Regex Predicate
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractReplicatedMapOperation |
class |
EvictionOperation
Evicts set of entries from the record store.
|
class |
PutAllOperationFactory
Factory class for
PutAllOperation . |
class |
ReplicateUpdateOperation
Replicates the update happened on the partition owner to the other nodes.
|
class |
ReplicateUpdateToCallerOperation
This operation will update the local record store with the update received from local/remote partition owner.
|
class |
RequestMapDataOperation
Collects and sends the replicated map data from the executing node to the caller via
SyncReplicatedMapDataOperation . |
class |
SyncReplicatedMapDataOperation<K,V>
Carries set of replicated map records for a partition from one node to another
|
class |
VersionResponsePair
Contains response and partition version for update operations on replicated map.
|
Modifier and Type | Class and Description |
---|---|
class |
RecordMigrationInfo |
class |
ReplicatedMapEntryView<K,V> |
Modifier and Type | Class and Description |
---|---|
class |
ReadResultSetImpl<E>
A list for the
ReadManyOperation . |
class |
RingbufferContainer
The RingbufferContainer is responsible for storing the actual content of a ringbuffer.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRingBufferOperation |
class |
AddAllBackupOperation |
class |
AddAllOperation |
class |
AddBackupOperation |
class |
AddOperation |
class |
GenericOperation |
class |
ReadManyOperation |
class |
ReadOneOperation |
class |
ReplicationOperation |
Modifier and Type | Interface and Description |
---|---|
interface |
EventRegistration
The result of a Event Registration.
|
interface |
ObjectNamespace
An ObjectNamespace that makes identification of 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 to a
Runnable . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractNamedOperation |
class |
BinaryOperationFactory |
class |
SerializableList |
class |
UnmodifiableLazyList<E> |
Modifier and Type | Class and Description |
---|---|
class |
EventEnvelope
An Envelope around an event object.
|
class |
Registration |
class |
TrueEventFilter
An event filter which does not filter any event and always evaluates
true results. |
Modifier and Type | Class and Description |
---|---|
class |
DeregistrationOperation |
class |
PostJoinRegistrationOperation |
class |
RegistrationOperation |
class |
SendEventOperation |
Modifier and Type | Class and Description |
---|---|
class |
Backup |
class |
IsStillExecutingOperation
An operation that checks if another operation is still running.
|
class |
PartitionIteratingOperation |
static class |
PartitionIteratingOperation.PartitionResponse |
class |
TraceableIsStillExecutingOperation |
Modifier and Type | Class and Description |
---|---|
class |
BackupResponse
The {Response} for a
BackupOperation . |
class |
CallTimeoutResponse
An response that indicates that the execution of a single call ran into a timeout.
|
class |
ErrorResponse |
class |
NormalResponse
A NormalResponse is send when an Operation needs to return a value.
|
class |
Response
|
Modifier and Type | Class and Description |
---|---|
class |
DistributedObjectEventPacket |
Modifier and Type | Class and Description |
---|---|
class |
DistributedObjectDestroyOperation |
class |
InitializeDistributedObjectOperation |
class |
PostJoinProxyOperation |
Modifier and Type | Class and Description |
---|---|
class |
PublishOperation |
class |
TopicEvent |
Modifier and Type | Class and Description |
---|---|
class |
ReliableTopicMessage
The Object that is going to be stored in the Ringbuffer.
|
Modifier and Type | Class and Description |
---|---|
class |
TransactionOptions
Contains the configuration for a Hazelcast transaction.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TargetAwareTransactionLogRecord
Represents a change made in a transaction on a specific target Address.
|
interface |
TransactionLogRecord
Represents a change made in a transaction e.g.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadcastTxRollbackOperation |
class |
CreateAllowedDuringPassiveStateTxBackupLogOperation |
class |
CreateTxBackupLogOperation |
class |
PurgeAllowedDuringPassiveStateTxBackupLogOperation |
class |
PurgeTxBackupLogOperation |
class |
ReplicateAllowedDuringPassiveStateTxBackupLogOperation |
class |
ReplicateTxBackupLogOperation
Replicates the transactionlog to a remote system.
|
class |
RollbackAllowedDuringPassiveStateTxBackupLogOperation |
class |
RollbackTxBackupLogOperation |
class |
TxBaseOperation |
Modifier and Type | Class and Description |
---|---|
class |
SerializableXID |
class |
XATransactionDTO |
Modifier and Type | Class and Description |
---|---|
class |
BaseXAOperation |
class |
ClearRemoteTransactionBackupOperation |
class |
ClearRemoteTransactionOperation |
class |
CollectRemoteTransactionsOperation |
class |
CollectRemoteTransactionsOperationFactory |
class |
FinalizeRemoteTransactionBackupOperation |
class |
FinalizeRemoteTransactionOperation |
class |
PutRemoteTransactionBackupOperation |
class |
PutRemoteTransactionOperation |
class |
XaReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
WanReplicationEvent
Event class used to transmit the actual event object
|
Modifier and Type | Class and Description |
---|---|
class |
SessionState
Wrapper class which holds session attributes
|
Modifier and Type | Class and Description |
---|---|
class |
DeleteSessionEntryProcessor
Entry processor which removes SessionState values if
invalidate is true.
|
class |
GetAttributeEntryProcessor
Entry processor which return attributes of SessionState values
|
class |
GetAttributeNamesEntryProcessor
Entry processor which return attributes keySet of SessionState values
|
class |
GetSessionStateEntryProcessor
Entry processor which return SessionState object stored in distributed map
|
class |
SessionUpdateEntryProcessor
Entry processor which updates SessionState attributes stored in distributed map
If value of attribute is set to null.
|
Copyright © 2016 Hazelcast, Inc.. All Rights Reserved.