|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| Packages that use DataSerializable | |
|---|---|
| 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.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 | This package contains Lock for Hazelcast. The ILock is the distributed version of the 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.local | Provides local classes for 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.operation | Package for map operations. |
| 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.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.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.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.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.xa | Provides implementation for Hazelcast XA 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. |
| Uses of DataSerializable in com.hazelcast.cache |
|---|
| Classes in com.hazelcast.cache that implement DataSerializable | |
|---|---|
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
|
| Uses of DataSerializable in com.hazelcast.cache.impl |
|---|
| Subinterfaces of DataSerializable in com.hazelcast.cache.impl | |
|---|---|
interface |
CacheEventData
Internal event data wrapper used during publishing and dispatching events. |
| Classes in com.hazelcast.cache.impl that implement DataSerializable | |
|---|---|
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 |
CacheStatisticsImpl
CacheStatistics implementation for ICache. |
| Uses of DataSerializable in com.hazelcast.cache.impl.operation |
|---|
| Classes in com.hazelcast.cache.impl.operation that implement DataSerializable | |
|---|---|
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 AbstractCacheService.destroyCache(String, boolean, String). |
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 |
CachePutAllBackupOperation
Cache PutAllBackup Operation is the backup operation used by load all operation. |
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 com.hazelcast.cache.impl.ICacheRecordStore#put(Data, Object, ExpiryPolicy, String) and
com.hazelcast.cache.impl.ICacheRecordStore#getAndPut(Data, Object, ExpiryPolicy, String). |
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. |
| Uses of DataSerializable in com.hazelcast.cache.impl.record |
|---|
| Classes in com.hazelcast.cache.impl.record that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.client.impl.client |
|---|
| Classes in com.hazelcast.client.impl.client that implement DataSerializable | |
|---|---|
class |
ClientResponse
|
| Uses of DataSerializable in com.hazelcast.client.impl.operations |
|---|
| Classes in com.hazelcast.client.impl.operations that implement DataSerializable | |
|---|---|
class |
ClientDisconnectionOperation
|
class |
ClientReAuthOperation
|
class |
GetConnectedClientsOperation
|
class |
OperationFactoryWrapper
|
class |
PostJoinClientOperation
|
| Uses of DataSerializable in com.hazelcast.cluster |
|---|
| Classes in com.hazelcast.cluster that implement DataSerializable | |
|---|---|
class |
MemberInfo
|
| Uses of DataSerializable in com.hazelcast.cluster.client |
|---|
| Classes in com.hazelcast.cluster.client that implement DataSerializable | |
|---|---|
class |
ClientInitialMembershipEvent
|
class |
ClientMembershipEvent
|
class |
MemberAttributeChange
|
| Uses of DataSerializable in com.hazelcast.cluster.impl |
|---|
| Classes in com.hazelcast.cluster.impl that implement DataSerializable | |
|---|---|
class |
BindMessage
|
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
|
| Uses of DataSerializable in com.hazelcast.cluster.impl.operations |
|---|
| Classes in com.hazelcast.cluster.impl.operations that implement DataSerializable | |
|---|---|
class |
AuthenticationFailureOperation
|
class |
AuthorizationOperation
|
class |
BeforeJoinCheckFailureOperation
|
class |
ConfigMismatchOperation
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated. |
class |
FinalizeJoinOperation
|
class |
GroupMismatchOperation
|
class |
HeartbeatOperation
|
class |
JoinCheckOperation
|
class |
JoinRequestOperation
|
class |
MasterClaimOperation
|
class |
MasterConfirmationOperation
|
class |
MasterDiscoveryOperation
|
class |
MemberAttributeChangedOperation
|
class |
MemberInfoUpdateOperation
|
class |
MemberRemoveOperation
|
class |
MergeClustersOperation
|
class |
PostJoinOperation
|
class |
PrepareMergeOperation
|
class |
SetMasterOperation
|
| Uses of DataSerializable in com.hazelcast.collection.impl.collection |
|---|
| Classes in com.hazelcast.collection.impl.collection that implement DataSerializable | |
|---|---|
class |
CollectionContainer
|
class |
CollectionEvent
|
class |
CollectionEventFilter
|
class |
CollectionItem
|
class |
TxCollectionItem
|
| Uses of DataSerializable in com.hazelcast.collection.impl.collection.operations |
|---|
| Classes in com.hazelcast.collection.impl.collection.operations that implement DataSerializable | |
|---|---|
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
|
| Uses of DataSerializable in com.hazelcast.collection.impl.list |
|---|
| Classes in com.hazelcast.collection.impl.list that implement DataSerializable | |
|---|---|
class |
ListContainer
|
| Uses of DataSerializable in com.hazelcast.collection.impl.list.operations |
|---|
| Classes in com.hazelcast.collection.impl.list.operations that implement DataSerializable | |
|---|---|
class |
ListAddAllOperation
|
class |
ListAddOperation
|
class |
ListGetOperation
|
class |
ListIndexOfOperation
|
class |
ListRemoveOperation
|
class |
ListReplicationOperation
|
class |
ListSetBackupOperation
|
class |
ListSetOperation
|
class |
ListSubOperation
|
| Uses of DataSerializable in com.hazelcast.collection.impl.queue |
|---|
| Classes in com.hazelcast.collection.impl.queue that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.collection.impl.queue.operations |
|---|
| Classes in com.hazelcast.collection.impl.queue.operations that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.collection.impl.set |
|---|
| Classes in com.hazelcast.collection.impl.set that implement DataSerializable | |
|---|---|
class |
SetContainer
|
| Uses of DataSerializable in com.hazelcast.collection.impl.set.operations |
|---|
| Classes in com.hazelcast.collection.impl.set.operations that implement DataSerializable | |
|---|---|
class |
SetReplicationOperation
|
| Uses of DataSerializable in com.hazelcast.collection.impl.txncollection |
|---|
| Classes in com.hazelcast.collection.impl.txncollection that implement DataSerializable | |
|---|---|
class |
CollectionTransactionLog
|
| Uses of DataSerializable in com.hazelcast.collection.impl.txncollection.operations |
|---|
| Classes in com.hazelcast.collection.impl.txncollection.operations that implement DataSerializable | |
|---|---|
class |
CollectionPrepareBackupOperation
|
class |
CollectionPrepareOperation
|
class |
CollectionReserveAddOperation
|
class |
CollectionReserveRemoveOperation
|
class |
CollectionRollbackBackupOperation
|
class |
CollectionRollbackOperation
|
class |
CollectionTransactionRollbackOperation
|
class |
CollectionTxnAddBackupOperation
|
class |
CollectionTxnAddOperation
|
class |
CollectionTxnRemoveBackupOperation
|
class |
CollectionTxnRemoveOperation
|
| Uses of DataSerializable in com.hazelcast.collection.impl.txnqueue |
|---|
| Classes in com.hazelcast.collection.impl.txnqueue that implement DataSerializable | |
|---|---|
class |
QueueTransactionLog
This class contains Transaction log for the Queue. |
class |
TxQueueItem
Transactional Queue Item. |
| Uses of DataSerializable in com.hazelcast.collection.impl.txnqueue.operations |
|---|
| Classes in com.hazelcast.collection.impl.txnqueue.operations that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.concurrent.atomiclong.operations |
|---|
| Classes in com.hazelcast.concurrent.atomiclong.operations that implement DataSerializable | |
|---|---|
class |
AddAndGetOperation
|
class |
AtomicLongBackupAwareOperation
|
class |
AtomicLongBaseOperation
|
class |
AtomicLongReplicationOperation
|
class |
GetAndAddOperation
|
| Uses of DataSerializable in com.hazelcast.concurrent.atomicreference.operations |
|---|
| Classes in com.hazelcast.concurrent.atomicreference.operations that implement DataSerializable | |
|---|---|
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
|
| Uses of DataSerializable in com.hazelcast.concurrent.countdownlatch |
|---|
| Classes in com.hazelcast.concurrent.countdownlatch that implement DataSerializable | |
|---|---|
class |
CountDownLatchContainer
|
| Uses of DataSerializable in com.hazelcast.concurrent.countdownlatch.operations |
|---|
| Classes in com.hazelcast.concurrent.countdownlatch.operations that implement DataSerializable | |
|---|---|
class |
AwaitOperation
|
class |
CountDownLatchBackupOperation
|
class |
CountDownLatchReplicationOperation
|
class |
CountDownOperation
|
class |
GetCountOperation
|
class |
SetCountOperation
|
| Uses of DataSerializable in com.hazelcast.concurrent.lock |
|---|
| Classes in com.hazelcast.concurrent.lock that implement DataSerializable | |
|---|---|
class |
InternalLockNamespace
|
class |
LockStoreImpl
|
| Uses of DataSerializable in com.hazelcast.concurrent.lock.operations |
|---|
| Classes in com.hazelcast.concurrent.lock.operations that implement DataSerializable | |
|---|---|
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
|
| Uses of DataSerializable in com.hazelcast.concurrent.semaphore |
|---|
| Classes in com.hazelcast.concurrent.semaphore that implement DataSerializable | |
|---|---|
class |
SemaphoreContainer
|
| Uses of DataSerializable in com.hazelcast.concurrent.semaphore.operations |
|---|
| Classes in com.hazelcast.concurrent.semaphore.operations that implement DataSerializable | |
|---|---|
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
|
| Uses of DataSerializable in com.hazelcast.config |
|---|
| Classes in com.hazelcast.config that implement DataSerializable | |
|---|---|
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) |
| Uses of DataSerializable in com.hazelcast.console |
|---|
| Classes in com.hazelcast.console that implement DataSerializable | |
|---|---|
class |
Echo
Echoes to screen |
| Uses of DataSerializable in com.hazelcast.core |
|---|
| Subinterfaces of DataSerializable in com.hazelcast.core | |
|---|---|
interface |
Member
Cluster member interface. |
| Classes in com.hazelcast.core that implement DataSerializable | |
|---|---|
class |
MemberAttributeEvent
|
class |
MigrationEvent
An event fired when a partition migration starts, completes or fails. |
class |
PartitionAwareKey<K,P>
A PartitionAware key. |
| Uses of DataSerializable in com.hazelcast.executor.impl |
|---|
| Classes in com.hazelcast.executor.impl that implement DataSerializable | |
|---|---|
class |
RunnableAdapter<V>
An adapter that adapts a Runnable to become a Callable. |
| Uses of DataSerializable in com.hazelcast.executor.impl.operations |
|---|
| Classes in com.hazelcast.executor.impl.operations that implement DataSerializable | |
|---|---|
class |
CallableTaskOperation
|
class |
CancellationOperation
|
class |
MemberCallableTaskOperation
|
class |
ShutdownOperation
|
| Uses of DataSerializable in com.hazelcast.hibernate |
|---|
| Classes in com.hazelcast.hibernate that implement DataSerializable | |
|---|---|
class |
VersionAwareMapMergePolicy
A merge policy implementation to handle split brain remerges based on the timestamps stored in the values. |
| Uses of DataSerializable in com.hazelcast.hibernate.local |
|---|
| Classes in com.hazelcast.hibernate.local that implement DataSerializable | |
|---|---|
class |
Invalidation
An invalidation messages |
class |
Timestamp
Hazelcast compatible implementation of a timestamp for internal eviction |
| Uses of DataSerializable in com.hazelcast.instance |
|---|
| Classes in com.hazelcast.instance that implement DataSerializable | |
|---|---|
class |
AbstractMember
|
class |
MemberImpl
|
| Uses of DataSerializable in com.hazelcast.internal.ascii.memcache |
|---|
| Classes in com.hazelcast.internal.ascii.memcache that implement DataSerializable | |
|---|---|
class |
MemcacheEntry
|
| Uses of DataSerializable in com.hazelcast.internal.ascii.rest |
|---|
| Classes in com.hazelcast.internal.ascii.rest that implement DataSerializable | |
|---|---|
class |
RestValue
|
| Uses of DataSerializable in com.hazelcast.internal.management.dto |
|---|
| Classes in com.hazelcast.internal.management.dto that implement DataSerializable | |
|---|---|
class |
MapConfigDTO
Serializable adapter for MapConfig |
| Uses of DataSerializable in com.hazelcast.internal.management.operation |
|---|
| Classes in com.hazelcast.internal.management.operation that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.map.impl |
|---|
| Subinterfaces of DataSerializable in com.hazelcast.map.impl | |
|---|---|
interface |
EventData
General contract for map event data. |
| Classes in com.hazelcast.map.impl that implement DataSerializable | |
|---|---|
class |
EntryEventData
An entry's event data. |
class |
EntryEventFilter
|
class |
MapEntrySet
|
class |
MapEventData
Map wide event's data. |
class |
MapKeySet
|
class |
MapPartitionEventData
Contains the data related to a map partition event |
class |
MapPartitionLostEventFilter
|
class |
MapValueCollection
|
class |
QueryEventFilter
|
class |
QueryResult
|
class |
SimpleEntryView<K,V>
SimpleEntryView is an implementation of EntryView and also it is writable. |
class |
SyntheticEventFilter
Wrapper class for a filter which does not want to receive synthetic events. |
| Uses of DataSerializable in com.hazelcast.map.impl.operation |
|---|
| Uses of DataSerializable in com.hazelcast.map.impl.record |
|---|
| Classes in com.hazelcast.map.impl.record that implement DataSerializable | |
|---|---|
class |
RecordInfo
Record info. |
class |
RecordReplicationInfo
|
class |
RecordStatistics
TODO empty statistics. |
| Uses of DataSerializable in com.hazelcast.map.impl.tx |
|---|
| Classes in com.hazelcast.map.impl.tx that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.map.impl.wan |
|---|
| Classes in com.hazelcast.map.impl.wan that implement DataSerializable | |
|---|---|
class |
MapReplicationRemove
|
class |
MapReplicationUpdate
|
| Uses of DataSerializable in com.hazelcast.map.merge |
|---|
| Subinterfaces of DataSerializable in com.hazelcast.map.merge | |
|---|---|
interface |
MapMergePolicy
A policy for merging maps after a splitbrain was detected and the different network partitions need to be merged. |
| Classes in com.hazelcast.map.merge that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.mapreduce.aggregation.impl |
|---|
| Classes in com.hazelcast.mapreduce.aggregation.impl that implement DataSerializable | |
|---|---|
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>
The default supplier for Predicates, used
to filter and optionally transform data (using the given
Supplier). |
class |
SetAdapter<E>
A simple adapter class to serialize values of a Set using
Hazelcast serialization support. |
| Uses of DataSerializable in com.hazelcast.mapreduce.impl |
|---|
| Classes in com.hazelcast.mapreduce.impl that implement DataSerializable | |
|---|---|
class |
CombinerResultList<E>
This ArrayList subclass exists to prevent
DefaultContext.CollectingCombinerFactory
created collections to be mixed up with user provided List results from
Combiners. |
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. |
| Uses of DataSerializable in com.hazelcast.mapreduce.impl.notification |
|---|
| Classes in com.hazelcast.mapreduce.impl.notification that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.mapreduce.impl.operation |
|---|
| Classes in com.hazelcast.mapreduce.impl.operation that implement DataSerializable | |
|---|---|
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 |
| Uses of DataSerializable in com.hazelcast.multimap.impl |
|---|
| Classes in com.hazelcast.multimap.impl that implement DataSerializable | |
|---|---|
class |
MultiMapEventFilter
|
class |
MultiMapRecord
|
| Uses of DataSerializable in com.hazelcast.multimap.impl.operations |
|---|
| Classes in com.hazelcast.multimap.impl.operations that implement DataSerializable | |
|---|---|
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
|
| Uses of DataSerializable in com.hazelcast.multimap.impl.txn |
|---|
| Classes in com.hazelcast.multimap.impl.txn that implement DataSerializable | |
|---|---|
class |
MultiMapTransactionLog
|
class |
TxnCommitBackupOperation
|
class |
TxnCommitOperation
|
class |
TxnGenerateRecordIdOperation
|
class |
TxnLockAndGetOperation
|
class |
TxnPutBackupOperation
|
class |
TxnPutOperation
|
class |
TxnRemoveAllBackupOperation
|
class |
TxnRemoveAllOperation
|
class |
TxnRemoveBackupOperation
|
class |
TxnRemoveOperation
|
| Uses of DataSerializable in com.hazelcast.nio |
|---|
| Classes in com.hazelcast.nio that implement DataSerializable | |
|---|---|
class |
Address
Represents an address of a member in the cluster. |
| Uses of DataSerializable in com.hazelcast.nio.serialization |
|---|
| Subinterfaces of DataSerializable in com.hazelcast.nio.serialization | |
|---|---|
interface |
IdentifiedDataSerializable
IdentifiedDataSerializable is an extension to DataSerializable
to avoid reflection during de-serialization. |
| Uses of DataSerializable in com.hazelcast.partition |
|---|
| Classes in com.hazelcast.partition that implement DataSerializable | |
|---|---|
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
|
| Uses of DataSerializable in com.hazelcast.partition.client |
|---|
| Classes in com.hazelcast.partition.client that implement DataSerializable | |
|---|---|
class |
PartitionsResponse
|
| Uses of DataSerializable in com.hazelcast.partition.impl |
|---|
| Classes in com.hazelcast.partition.impl that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.query |
|---|
| Classes in com.hazelcast.query that implement DataSerializable | |
|---|---|
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. |
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. |
| Uses of DataSerializable in com.hazelcast.query.impl |
|---|
| Classes in com.hazelcast.query.impl that implement DataSerializable | |
|---|---|
class |
QueryResultEntryImpl
Multiple result set for Predicates |
| Uses of DataSerializable in com.hazelcast.replicatedmap.impl.messages |
|---|
| Classes in com.hazelcast.replicatedmap.impl.messages that implement DataSerializable | |
|---|---|
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 |
| Uses of DataSerializable in com.hazelcast.replicatedmap.impl.operation |
|---|
| Classes in com.hazelcast.replicatedmap.impl.operation that implement DataSerializable | |
|---|---|
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 |
| Uses of DataSerializable in com.hazelcast.replicatedmap.impl.record |
|---|
| Classes in com.hazelcast.replicatedmap.impl.record that implement DataSerializable | |
|---|---|
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 |
| Uses of DataSerializable in com.hazelcast.ringbuffer.impl |
|---|
| Classes in com.hazelcast.ringbuffer.impl that implement DataSerializable | |
|---|---|
class |
ReadResultSetImpl<E>
A list for the ReadManyOperation. |
class |
RingbufferContainer
The RingbufferContainer is responsible for storing the actual content of a ringbuffer. |
| Uses of DataSerializable in com.hazelcast.ringbuffer.impl.operations |
|---|
| Classes in com.hazelcast.ringbuffer.impl.operations that implement DataSerializable | |
|---|---|
class |
AbstractRingBufferOperation
|
class |
AddAllBackupOperation
|
class |
AddAllOperation
|
class |
AddBackupOperation
|
class |
AddOperation
|
class |
GenericOperation
|
class |
ReadManyOperation
|
class |
ReadOneOperation
|
class |
ReplicationOperation
|
| Uses of DataSerializable in com.hazelcast.spi |
|---|
| Subinterfaces of DataSerializable in com.hazelcast.spi | |
|---|---|
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. |
| Classes in com.hazelcast.spi that implement DataSerializable | |
|---|---|
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. |
| Uses of DataSerializable in com.hazelcast.spi.impl |
|---|
| Classes in com.hazelcast.spi.impl that implement DataSerializable | |
|---|---|
class |
AbstractNamedOperation
|
class |
BinaryOperationFactory
|
class |
DistributedObjectEventPacket
|
class |
SerializableCollection
|
| Uses of DataSerializable in com.hazelcast.spi.impl.eventservice.impl |
|---|
| Classes in com.hazelcast.spi.impl.eventservice.impl that implement DataSerializable | |
|---|---|
class |
EmptyFilter
|
class |
EventPacket
|
class |
Registration
|
| Uses of DataSerializable in com.hazelcast.spi.impl.eventservice.impl.operations |
|---|
| Classes in com.hazelcast.spi.impl.eventservice.impl.operations that implement DataSerializable | |
|---|---|
class |
DeregistrationOperation
|
class |
PostJoinRegistrationOperation
|
class |
RegistrationOperation
|
class |
SendEventOperation
|
| Uses of DataSerializable in com.hazelcast.spi.impl.operationservice.impl.operations |
|---|
| Classes in com.hazelcast.spi.impl.operationservice.impl.operations that implement DataSerializable | |
|---|---|
class |
Backup
|
class |
IsStillExecutingOperation
An operation that checks if another operation is still running. |
class |
PartitionIteratingOperation
|
static class |
PartitionIteratingOperation.PartitionResponse
|
class |
TraceableIsStillExecutingOperation
|
| Uses of DataSerializable in com.hazelcast.spi.impl.operationservice.impl.responses |
|---|
| Classes in com.hazelcast.spi.impl.operationservice.impl.responses that implement DataSerializable | |
|---|---|
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
A Response is a result of an Operation being executed. |
| Uses of DataSerializable in com.hazelcast.spi.impl.proxyservice.impl.operations |
|---|
| Classes in com.hazelcast.spi.impl.proxyservice.impl.operations that implement DataSerializable | |
|---|---|
class |
DistributedObjectDestroyOperation
|
class |
PostJoinProxyOperation
|
| Uses of DataSerializable in com.hazelcast.topic.impl |
|---|
| Classes in com.hazelcast.topic.impl that implement DataSerializable | |
|---|---|
class |
PublishOperation
|
class |
TopicEvent
|
| Uses of DataSerializable in com.hazelcast.topic.impl.reliable |
|---|
| Classes in com.hazelcast.topic.impl.reliable that implement DataSerializable | |
|---|---|
class |
ReliableTopicMessage
The Object that is going to be stored in the Ringbuffer. |
| Uses of DataSerializable in com.hazelcast.transaction |
|---|
| Classes in com.hazelcast.transaction that implement DataSerializable | |
|---|---|
class |
TransactionOptions
Contains the configuration for a Hazelcast transaction. |
| Uses of DataSerializable in com.hazelcast.transaction.impl |
|---|
| Subinterfaces of DataSerializable in com.hazelcast.transaction.impl | |
|---|---|
interface |
KeyAwareTransactionLog
|
interface |
TransactionLog
|
| Classes in com.hazelcast.transaction.impl that implement DataSerializable | |
|---|---|
class |
BeginTxBackupOperation
|
class |
BroadcastTxRollbackOperation
|
class |
PurgeTxBackupOperation
|
class |
ReplicateTxOperation
|
class |
RollbackTxBackupOperation
|
| Uses of DataSerializable in com.hazelcast.transaction.impl.xa |
|---|
| Classes in com.hazelcast.transaction.impl.xa that implement DataSerializable | |
|---|---|
class |
ClearRemoteTransactionBackupOperation
|
class |
ClearRemoteTransactionOperation
|
class |
CollectRemoteTransactionsOperation
|
class |
CollectRemoteTransactionsOperationFactory
|
class |
FinalizeRemoteTransactionBackupOperation
|
class |
FinalizeRemoteTransactionOperation
|
class |
PutRemoteTransactionBackupOperation
|
class |
PutRemoteTransactionOperation
|
class |
SerializableXID
|
class |
XaReplicationOperation
|
class |
XATransactionHolder
|
| Uses of DataSerializable in com.hazelcast.util |
|---|
| Classes in com.hazelcast.util that implement DataSerializable | |
|---|---|
class |
QueryResultSet
Collection(Set) class for result of query operations. |
| Uses of DataSerializable in com.hazelcast.wan |
|---|
| Classes in com.hazelcast.wan that implement DataSerializable | |
|---|---|
class |
WanReplicationEvent
Event class used to transmit the actual event object |
| Uses of DataSerializable in com.hazelcast.web |
|---|
| Classes in com.hazelcast.web that implement DataSerializable | |
|---|---|
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. |
|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||