| Package | Description | 
|---|---|
| com.hazelcast.cache.impl.client | 
 
     Hazelcast JSR-107 aka JCache implementation
     Client Requests 
 | 
| com.hazelcast.client.impl.client | 
 This contains the Requests and other DTO's exchanged between client/server 
 | 
| com.hazelcast.cluster.client | 
 This package contains the client cluster functionality. 
 | 
| com.hazelcast.collection.impl.collection.client | |
| com.hazelcast.collection.impl.list.client | |
| com.hazelcast.collection.impl.queue.client | 
 This package contains client requests for the IQueue. 
 | 
| com.hazelcast.collection.impl.txncollection.client | |
| com.hazelcast.collection.impl.txnlist.client | |
| com.hazelcast.collection.impl.txnqueue.client | |
| com.hazelcast.collection.impl.txnset.client | |
| com.hazelcast.concurrent.atomiclong.client | 
 This package contains client requests for the IAtomicLong. 
This package contains all the client request object to operate on the IAtomicLong that are send by the client.  | 
| com.hazelcast.concurrent.atomicreference.client | 
 This package contains client requests for the IAtomicLong. 
This package contains all the client request object to operate on the IAtomicLong that are send by the client.  | 
| com.hazelcast.concurrent.countdownlatch.client | 
 This package contains client requests for the ICountDownLatch. 
This package contains all the client requests object to operate on the ICountDownLatch that are send by the client.  | 
| com.hazelcast.concurrent.lock.client | 
 This package contains client requests for the ILock. 
This package contains all the client requests object to operate on the ILock that are send by the client.  | 
| com.hazelcast.concurrent.semaphore.client | 
 This package contains client requests for the ISemaphore. 
 | 
| com.hazelcast.executor.impl.client | 
 This package contains client requests for the IExecutorService. 
 | 
| com.hazelcast.internal.serialization | 
 Contains the private serialization API + implementation. 
 | 
| com.hazelcast.internal.serialization.impl | |
| com.hazelcast.map.impl.client | 
 Contains client requests for the  
IMap | 
| com.hazelcast.mapreduce.impl.client | 
 This package contains request and response classes for communication between cluster
 members and Hazelcast native clients 
 | 
| com.hazelcast.mapreduce.impl.task | 
 This package contains the base implementation for a standard map reduce job. 
 | 
| com.hazelcast.multimap.impl.client | 
 Contains client requests for Hazelcast MultiMap module. 
 | 
| com.hazelcast.nio.serialization | 
 Contains interfaces/classes related to serialization;
 such as serializer interfaces, input/output streams. 
 | 
| com.hazelcast.partition.client | 
 Contains client functionality for partition related information. 
 | 
| com.hazelcast.replicatedmap.impl.client | 
 This package contains classes for client communication on replicated map implementation 
 | 
| com.hazelcast.ringbuffer.impl.client | |
| com.hazelcast.security | 
 Provides interfaces/classes for Hazelcast security implementation. 
 | 
| com.hazelcast.spi.impl | 
 Contains implementations for Hazelcast SPI. 
 | 
| com.hazelcast.topic.impl.client | 
 This package contains client requests for the ITopic. 
 | 
| com.hazelcast.transaction.client | 
 This package contains client transaction code 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractCacheRequest  | 
class  | 
CacheAddEntryListenerRequest
Client request which registers an event listener on behalf of the client and delegates the received events
 back to client. 
 | 
class  | 
CacheAddInvalidationListenerRequest  | 
class  | 
CacheAddPartitionLostListenerRequest  | 
class  | 
CacheBatchInvalidationMessage  | 
class  | 
CacheClearRequest
This client request  specifically calls  
CacheClearOperationFactory on the server side. | 
class  | 
CacheContainsKeyRequest
This client request  specifically calls  
CacheContainsKeyOperation on the server side. | 
class  | 
CacheCreateConfigRequest
This client request  specifically calls  
CacheCreateConfigOperation on the server side. | 
class  | 
CacheDestroyRequest
This client request  specifically calls  
CacheDestroyOperation on the server side. | 
class  | 
CacheEntryProcessorRequest
This client request  specifically calls  
CacheEntryProcessorOperation on the server side. | 
class  | 
CacheGetAllRequest
This client request  specifically calls  
CacheGetAllOperationFactory on the server side. | 
class  | 
CacheGetAndRemoveRequest
This client request  specifically calls  
CacheGetAndRemoveOperation on the server side. | 
class  | 
CacheGetAndReplaceRequest
This client request  specifically calls  
CacheGetAndReplaceOperation on the server side. | 
class  | 
CacheGetConfigRequest
This client request  specifically calls  
CacheGetConfigOperation on the server side. | 
class  | 
CacheGetRequest
This client request  specifically calls  
CacheGetOperation on the server side. | 
class  | 
CacheInvalidationMessage  | 
class  | 
CacheIterateRequest
This client request  specifically calls  
CacheKeyIteratorOperation on the server side. | 
class  | 
CacheListenerRegistrationRequest
This client request  specifically calls  
CacheListenerRegistrationOperation on the server side. | 
class  | 
CacheLoadAllRequest
This client request  specifically calls  
CacheLoadAllOperationFactory on the server side. | 
class  | 
CacheManagementConfigRequest
This client request  specifically calls  
CacheManagementConfigOperation on the server side. | 
class  | 
CachePutAllRequest
This client request that puts entries as batch into specified partition. 
 | 
class  | 
CachePutIfAbsentRequest
This client request  specifically calls  
CachePutIfAbsentOperation on the server side. | 
class  | 
CachePutRequest
This client request  specifically calls  
CachePutOperation on the server side. | 
class  | 
CacheRemoveEntryListenerRequest
Client request which unregisters the event listener on behalf of the client. 
 | 
class  | 
CacheRemoveInvalidationListenerRequest
Client request which unregisters the invalidation listener on behalf of the client. 
 | 
class  | 
CacheRemovePartitionLostListenerRequest  | 
class  | 
CacheRemoveRequest
This client request  specifically calls  
CacheRemoveOperation on the server side. | 
class  | 
CacheReplaceRequest
This client request  specifically calls  
CacheReplaceOperation on the server side. | 
class  | 
CacheSingleInvalidationMessage  | 
class  | 
CacheSizeRequest
This client request  specifically calls  
CacheSizeOperationFactory on the server side. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AddDistributedObjectListenerRequest  | 
class  | 
AllPartitionsClientRequest
Base class for client request that will run on all partitions. 
 | 
class  | 
AuthenticationRequest
Client Authentication Request that holds credentials 
 | 
class  | 
BaseClientAddListenerRequest
Base class for add listener requests 
 | 
class  | 
BaseClientRemoveListenerRequest  | 
class  | 
CallableClientRequest  | 
class  | 
ClientCreateRequest  | 
class  | 
ClientDestroyRequest  | 
class  | 
ClientPrincipal  | 
class  | 
ClientRequest  | 
class  | 
DistributedObjectInfo  | 
class  | 
GenericError  | 
class  | 
GetDistributedObjectsRequest  | 
class  | 
GetMemberListRequest
Returns member list to client 
 | 
class  | 
InvocationClientRequest  | 
class  | 
KeyBasedClientRequest  | 
class  | 
MultiPartitionClientRequest  | 
class  | 
MultiTargetClientRequest
Base class for client request that will be send more than one member 
 | 
class  | 
PartitionClientRequest
Base class for partition based client request. 
 | 
class  | 
RemoveAllListeners
When a connection does not respond to heart-beat we switch the listeners to another endpoint
 If somehow connection starts to respond heart-beat we need to signal the endpoint to remove the listeners
 An internal request should not be used for user calls. 
 | 
class  | 
RemoveDistributedObjectListenerRequest
Client request to remove a distributed object listener from a remote node. 
 | 
class  | 
TargetClientRequest  | 
| Modifier and Type | Method and Description | 
|---|---|
Portable | 
ClientPortableFactory.create(int classId)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AddMembershipListenerRequest  | 
class  | 
ClientPingRequest  | 
class  | 
RegisterMembershipListenerRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CollectionAddAllRequest  | 
class  | 
CollectionAddListenerRequest
this class is used to attach a listener to node for collections 
 | 
class  | 
CollectionAddRequest  | 
class  | 
CollectionClearRequest  | 
class  | 
CollectionCompareAndRemoveRequest  | 
class  | 
CollectionContainsRequest  | 
class  | 
CollectionGetAllRequest  | 
class  | 
CollectionIsEmptyRequest  | 
class  | 
CollectionRemoveListenerRequest  | 
class  | 
CollectionRemoveRequest  | 
class  | 
CollectionRequest  | 
class  | 
CollectionSizeRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ListAddAllRequest  | 
class  | 
ListAddRequest  | 
class  | 
ListGetRequest  | 
class  | 
ListIndexOfRequest  | 
class  | 
ListRemoveRequest  | 
class  | 
ListSetRequest  | 
class  | 
ListSubRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AddListenerRequest
this class is used to attach a listener to targeted node which sends back the events to client for a queue 
 | 
class  | 
ClearRequest
Provides the request service for  
ClearOperation | 
class  | 
CompareAndRemoveRequest
Provides the request service for  
CompareAndRemoveOperation | 
class  | 
ContainsRequest
Provides the request service for  
ContainsOperation | 
class  | 
DrainRequest
Provides the request service for  
DrainOperation | 
class  | 
IsEmptyRequest
Request to check if the Queue is empty 
 | 
class  | 
IteratorRequest
Provides the request service for  
IteratorOperation | 
class  | 
OfferRequest
Provides the request service for  
OfferOperation | 
class  | 
PeekRequest
Provides the request service for  
PeekOperation | 
class  | 
PollRequest
Provides the request service for  
PollOperation | 
class  | 
QueueRequest
This class contains methods for all Queue requests
 such as  
ClearRequest. | 
class  | 
RemoveListenerRequest
Remove listener request belong to the Queue item. 
 | 
class  | 
RemoveRequest
Remove Request for the Queue. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TxnCollectionRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TxnListAddRequest  | 
class  | 
TxnListRemoveRequest  | 
class  | 
TxnListSizeRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TxnOfferRequest
Request for transactional offer operation. 
 | 
class  | 
TxnPeekRequest
Request for transactional peek operation. 
 | 
class  | 
TxnPollRequest
Request for transactional poll operation. 
 | 
class  | 
TxnSizeRequest
Request for size of the Transactional Queue. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TxnSetAddRequest  | 
class  | 
TxnSetRemoveRequest  | 
class  | 
TxnSetSizeRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AddAndGetRequest  | 
class  | 
AtomicLongRequest  | 
class  | 
GetAndAddRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractAlterRequest  | 
class  | 
AlterAndGetRequest  | 
class  | 
AlterRequest  | 
class  | 
ApplyRequest  | 
class  | 
CompareAndSetRequest  | 
class  | 
GetAndAlterRequest  | 
class  | 
GetAndSetRequest  | 
class  | 
GetRequest  | 
class  | 
IsNullRequest  | 
class  | 
ModifyRequest  | 
class  | 
ReadRequest  | 
class  | 
SetRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AwaitRequest  | 
class  | 
CountDownRequest  | 
class  | 
GetCountRequest  | 
class  | 
SetCountRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractIsLockedRequest  | 
class  | 
AbstractLockRequest  | 
class  | 
AbstractUnlockRequest  | 
class  | 
BeforeAwaitRequest  | 
class  | 
GetLockCountRequest  | 
class  | 
GetRemainingLeaseRequest  | 
class  | 
IsLockedRequest  | 
class  | 
LockRequest  | 
class  | 
SignalRequest  | 
class  | 
UnlockRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AcquireRequest  | 
class  | 
AvailableRequest  | 
class  | 
InitRequest  | 
class  | 
ReduceRequest  | 
class  | 
ReleaseRequest  | 
class  | 
SemaphoreRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CancellationRequest  | 
class  | 
IsShutdownRequest  | 
class  | 
PartitionTargetCallableRequest
A  
TargetClientRequest which sends a Callable task
 to a specific target. | 
class  | 
ShutdownRequest  | 
class  | 
SpecificTargetCallableRequest
A  
TargetClientRequest which sends
 a Callable task to the given target address. | 
| Modifier and Type | Method and Description | 
|---|---|
ClassDefinition | 
PortableContext.lookupOrRegisterClassDefinition(Portable portable)  | 
| Modifier and Type | Method and Description | 
|---|---|
Portable | 
MorphingPortableReader.readPortable(String fieldName)  | 
Portable | 
DefaultPortableReader.readPortable(String fieldName)  | 
Portable[] | 
MorphingPortableReader.readPortableArray(String fieldName)  | 
Portable[] | 
DefaultPortableReader.readPortableArray(String fieldName)  | 
| Modifier and Type | Method and Description | 
|---|---|
static int | 
SerializationUtil.getPortableVersion(Portable portable,
                  int defaultVersion)  | 
void | 
DefaultPortableWriter.writePortable(String fieldName,
             Portable portable)  | 
void | 
DefaultPortableWriter.writePortableArray(String fieldName,
                  Portable[] portables)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ClientCancellationRequest
This class is used to request a map reduce job cancellation on the job owning
 node from the emitting client. 
 | 
class  | 
ClientJobProcessInformationRequest
This class is used to retrieve current processed records and other statistics from
 emitting client to the job owning node. 
 | 
class  | 
ClientMapReduceRequest<KeyIn,ValueIn>
This class is used to prepare and start a map reduce job emitted by a client
 on a random node in the cluster (making it the job owner). 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TransferableJobProcessInformation
This implementation of  
JobProcessInformation is used to
 transmit the currently processed number of records and the partition states to a requesting
 client. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AddEntryListenerRequest  | 
class  | 
CountRequest  | 
class  | 
EntrySetRequest  | 
class  | 
GetAllRequest  | 
class  | 
KeyBasedContainsRequest
The KeyBasedContainsRequest can be used to determine if a key is available in a multimap (when value is null), or
 to check if a map-entry is stored in the multimap (value not null). 
 | 
class  | 
KeySetRequest  | 
class  | 
MultiMapAllPartitionRequest  | 
class  | 
MultiMapIsLockedRequest  | 
class  | 
MultiMapKeyBasedRequest  | 
class  | 
MultiMapLockRequest  | 
class  | 
MultiMapRequest  | 
class  | 
MultiMapUnlockRequest  | 
class  | 
PortableEntrySetResponse  | 
class  | 
PutRequest  | 
class  | 
RemoveAllRequest  | 
class  | 
RemoveEntryListenerRequest  | 
class  | 
TxnMultiMapGetRequest  | 
class  | 
TxnMultiMapPutRequest  | 
class  | 
TxnMultiMapRemoveAllRequest  | 
class  | 
TxnMultiMapRemoveRequest  | 
class  | 
TxnMultiMapRequest  | 
class  | 
TxnMultiMapSizeRequest  | 
class  | 
TxnMultiMapValueCountRequest  | 
class  | 
ValuesRequest  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
VersionedPortable
VersionedPortable is an extension to  
Portable
 to support per class version instead of a global serialization version. | 
| Modifier and Type | Method and Description | 
|---|---|
<P extends Portable>  | 
PortableReader.readPortable(String fieldName)  | 
| Modifier and Type | Method and Description | 
|---|---|
Portable | 
PortableFactory.create(int classId)
Creates a Portable instance using given class id 
 | 
Portable[] | 
PortableReader.readPortableArray(String fieldName)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
PortableWriter.writePortable(String fieldName,
             Portable portable)
Writes a Portable. 
 | 
void | 
PortableWriter.writePortableArray(String fieldName,
                  Portable[] portables)
Writes a an array of Portables. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AddPartitionLostListenerRequest  | 
class  | 
GetPartitionsRequest  | 
class  | 
RemovePartitionLostListenerRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractReplicatedMapClientRequest
Base class for all ReplicatedMap client request. 
 | 
class  | 
ClientReplicatedMapAddEntryListenerRequest
Client request class for  
ReplicatedMap.addEntryListener(com.hazelcast.core.EntryListener)
 implementation | 
class  | 
ClientReplicatedMapAddNearCacheListenerRequest
Internal Request to add listener to replicated map to invalidate near cache from client 
 | 
class  | 
ClientReplicatedMapClearRequest
Client request class for  
Map.clear() implementation | 
class  | 
ClientReplicatedMapContainsKeyRequest
Client request class for  
Map.containsKey(Object) implementation | 
class  | 
ClientReplicatedMapContainsValueRequest
Client request class for  
Map.containsValue(Object) implementation | 
class  | 
ClientReplicatedMapEntrySetRequest
Client request class for  
Map.entrySet() implementation | 
class  | 
ClientReplicatedMapGetRequest
Client request class for  
Map.get(Object) implementation | 
class  | 
ClientReplicatedMapIsEmptyRequest
Client request class for  
Map.isEmpty() implementation | 
class  | 
ClientReplicatedMapKeySetRequest
Client request class for  
Map.keySet() implementation | 
class  | 
ClientReplicatedMapPutAllRequest
Client request class for  
Map.putAll(java.util.Map) implementation | 
class  | 
ClientReplicatedMapPutTtlRequest
Client request class for  
ReplicatedMap.put(Object, Object, long, java.util.concurrent.TimeUnit)
 implementation | 
class  | 
ClientReplicatedMapRemoveEntryListenerRequest
Client request class for  
ReplicatedMap.removeEntryListener(String) implementation | 
class  | 
ClientReplicatedMapRemoveRequest
Client request class for  
Map.remove(Object) implementation | 
class  | 
ClientReplicatedMapSizeRequest
Client request class for  
Map.size() implementation | 
class  | 
ClientReplicatedMapValuesRequest
Client request class for  
Map.values() implementation | 
class  | 
ReplicatedMapEntries
An implementation of a portable implementing entry set for client results on entrySet requests 
 | 
class  | 
ReplicatedMapKeys
Class to implement a replicated map keySet result 
 | 
class  | 
ReplicatedMapPortableEntryEvent
Class to redirect entry listener events on the members to the listening client 
 | 
class  | 
ReplicatedMapValueCollection
Class implementing a replicated map value collection result 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AddAllRequest  | 
class  | 
AddRequest  | 
class  | 
CapacityRequest  | 
class  | 
HeadSequenceRequest  | 
class  | 
PortableReadResultSet<E>  | 
class  | 
ReadManyRequest  | 
class  | 
ReadOneRequest  | 
class  | 
RemainingCapacityRequest  | 
class  | 
RingbufferRequest  | 
class  | 
SizeRequest  | 
class  | 
TailSequenceRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractCredentials
Abstract implementation of  
Credentials | 
class  | 
UsernamePasswordCredentials
Simple implementation of  
Credentials using
 username and password as security attributes. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
PortableCachePartitionLostEvent  | 
class  | 
PortableCollection  | 
class  | 
PortableDistributedObjectEvent  | 
class  | 
PortableEntryEvent  | 
class  | 
PortableItemEvent  | 
class  | 
PortableMapPartitionLostEvent  | 
class  | 
PortablePartitionLostEvent  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AddMessageListenerRequest  | 
class  | 
PortableMessage  | 
class  | 
PublishRequest  | 
class  | 
RemoveMessageListenerRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
BaseTransactionRequest  | 
class  | 
BaseXATransactionRequest  | 
class  | 
ClearRemoteTransactionRequest  | 
class  | 
CollectXATransactionsRequest  | 
class  | 
CommitTransactionRequest  | 
class  | 
CommitXATransactionRequest  | 
class  | 
CreateTransactionRequest  | 
class  | 
CreateXATransactionRequest  | 
class  | 
FinalizeXATransactionRequest  | 
class  | 
PrepareXATransactionRequest  | 
class  | 
RollbackTransactionRequest  | 
class  | 
RollbackXATransactionRequest  | 
Copyright © 2016 Hazelcast, Inc.. All Rights Reserved.