Package | Description |
---|---|
com.hazelcast.client.proxy |
This package contains client side proxy implementations of the different Hazelcast data structures
and operation types
|
com.hazelcast.client.spi |
Contains classes/interfaces related to the Hazelcast client Service Provider Interface.
|
com.hazelcast.concurrent.atomicreference |
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the AtomicReference . |
com.hazelcast.concurrent.atomicreference.operations |
This package contains the operations on the IAtomicReference.
|
com.hazelcast.concurrent.lock | |
com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
com.hazelcast.internal.serialization.impl | |
com.hazelcast.jet.core.test |
Utilities for writing tests of Core API Processors.
|
com.hazelcast.nio |
This package contains classes related to New IO
|
com.hazelcast.spi |
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
|
com.hazelcast.spi.partition |
Contains the SPI for partition logic for Hazelcast.
|
com.hazelcast.spi.serialization |
Contains SPI related to serialization
|
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
|
Modifier and Type | Method and Description |
---|---|
protected void |
ClientMapProxy.fillPartitionToKeyData(Set<K> keys,
Map<Integer,List<Data>> partitionToKeyData,
Map<Object,Data> keyMap,
Map<Data,Object> reverseKeyMap) |
protected void |
ClientMapProxy.fillPartitionToKeyData(Set<K> keys,
Map<Integer,List<Data>> partitionToKeyData,
Map<Object,Data> keyMap,
Map<Data,Object> reverseKeyMap) |
protected void |
ClientMapProxy.fillPartitionToKeyData(Set<K> keys,
Map<Integer,List<Data>> partitionToKeyData,
Map<Object,Data> keyMap,
Map<Data,Object> reverseKeyMap) |
protected void |
NearCachedClientMapProxy.getAllInternal(Set<K> keys,
Map<Integer,List<Data>> partitionToKeyData,
List<Object> resultingKeyValuePairs) |
protected void |
ClientMapProxy.getAllInternal(Set<K> keys,
Map<Integer,List<Data>> partitionToKeyData,
List<Object> resultingKeyValuePairs) |
protected Map<K,Object> |
NearCachedClientMapProxy.prepareResult(Collection<Map.Entry<Data,Data>> entrySet) |
protected Map<K,Object> |
NearCachedClientMapProxy.prepareResult(Collection<Map.Entry<Data,Data>> entrySet) |
protected Map<K,Object> |
ClientMapProxy.prepareResult(Collection<Map.Entry<Data,Data>> entries) |
protected Map<K,Object> |
ClientMapProxy.prepareResult(Collection<Map.Entry<Data,Data>> entries) |
protected void |
NearCachedClientMapProxy.putAllInternal(Map<? extends K,? extends V> map,
Map<Integer,List<Map.Entry<Data,Data>>> entryMap) |
protected void |
NearCachedClientMapProxy.putAllInternal(Map<? extends K,? extends V> map,
Map<Integer,List<Map.Entry<Data,Data>>> entryMap) |
protected void |
ClientMapProxy.putAllInternal(Map<? extends K,? extends V> map,
Map<Integer,List<Map.Entry<Data,Data>>> entryMap) |
protected void |
ClientMapProxy.putAllInternal(Map<? extends K,? extends V> map,
Map<Integer,List<Map.Entry<Data,Data>>> entryMap) |
Modifier and Type | Method and Description |
---|---|
protected Data |
ClientProxy.toData(Object o) |
Modifier and Type | Method and Description |
---|---|
int |
ClientPartitionService.getPartitionId(Data key) |
Modifier and Type | Method and Description |
---|---|
Data |
AtomicReferenceContainer.get() |
Data |
AtomicReferenceContainer.getAndSet(Data value) |
Modifier and Type | Method and Description |
---|---|
boolean |
AtomicReferenceContainer.compareAndSet(Data expect,
Data value) |
boolean |
AtomicReferenceContainer.contains(Data expected) |
Data |
AtomicReferenceContainer.getAndSet(Data value) |
void |
AtomicReferenceContainer.set(Data value) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractAlterOperation.backup |
protected Data |
ApplyOperation.function |
protected Data |
AbstractAlterOperation.function |
protected Data |
ApplyOperation.returnValue |
Constructor and Description |
---|
AbstractAlterOperation(String name,
Data function) |
AlterAndGetOperation(String name,
Data function) |
AlterOperation(String name,
Data function) |
ApplyOperation(String name,
Data function) |
CompareAndSetOperation(String name,
Data expect,
Data update) |
ContainsOperation(String name,
Data contains) |
GetAndAlterOperation(String name,
Data function) |
GetAndSetOperation(String name,
Data newValue) |
MergeBackupOperation(String name,
Data newValue) |
MergeOperation(String name,
SplitBrainMergePolicy<Object,SplitBrainMergeTypes.AtomicReferenceMergeTypes> mergePolicy,
Data mergingValue) |
SetAndGetOperation(String name,
Data newValue) |
SetBackupOperation(String name,
Data newValue) |
SetOperation(String name,
Data newValue) |
Constructor and Description |
---|
AtomicReferenceReplicationOperation(Map<String,Data> migrationData) |
Modifier and Type | Method and Description |
---|---|
Data |
LockResource.getKey() |
Data |
ConditionKey.getKey() |
Data |
LockProxy.getKeyData() |
Modifier and Type | Method and Description |
---|---|
Set<Data> |
LockStoreProxy.getLockedKeys() |
Set<Data> |
LockStoreImpl.getLockedKeys() |
Set<Data> |
LockStore.getLockedKeys()
Return all locked keys for this store.
|
Modifier and Type | Method and Description |
---|---|
void |
LockStoreImpl.addAwait(Data key,
String conditionId,
String caller,
long threadId) |
boolean |
LockStoreProxy.canAcquireLock(Data key,
String caller,
long threadId) |
boolean |
LockStoreImpl.canAcquireLock(Data key,
String caller,
long threadId) |
boolean |
LockStore.canAcquireLock(Data key,
String caller,
long threadId)
Return if the key can be locked by the caller and thread ID.
|
boolean |
LockStoreProxy.extendLeaseTime(Data key,
String caller,
long threadId,
long leaseTime) |
boolean |
LockStoreImpl.extendLeaseTime(Data key,
String caller,
long threadId,
long leaseTime) |
boolean |
LockStore.extendLeaseTime(Data key,
String caller,
long threadId,
long leaseTime)
Extend the lease time for an already locked key.
|
boolean |
LockStoreProxy.forceUnlock(Data key) |
boolean |
LockStoreImpl.forceUnlock(Data key) |
boolean |
LockStore.forceUnlock(Data dataKey)
Unlock the key regardless of the owner.
|
void |
LockProxySupport.forceUnlock(NodeEngine nodeEngine,
Data key) |
com.hazelcast.concurrent.lock.LockResourceImpl |
LockStoreImpl.getLock(Data key) |
int |
LockStoreProxy.getLockCount(Data key) |
int |
LockStoreImpl.getLockCount(Data key) |
int |
LockStore.getLockCount(Data key)
Return the number of times a key was locked by the same owner (re-entered).
|
int |
LockProxySupport.getLockCount(NodeEngine nodeEngine,
Data key) |
WaitNotifyKey |
LockStoreImpl.getNotifiedKey(Data key) |
String |
LockStoreProxy.getOwnerInfo(Data dataKey) |
String |
LockStoreImpl.getOwnerInfo(Data key) |
String |
LockStore.getOwnerInfo(Data dataKey)
Return a string representation of the owner of the lock for a specific key.
|
long |
LockStoreProxy.getRemainingLeaseTime(Data key) |
long |
LockStoreImpl.getRemainingLeaseTime(Data key) |
long |
LockStore.getRemainingLeaseTime(Data key)
Return the remaining lease time for a specific key.
|
long |
LockProxySupport.getRemainingLeaseTime(NodeEngine nodeEngine,
Data key) |
int |
LockStoreImpl.getVersion(Data key) |
boolean |
LockStoreProxy.isLocked(Data key) |
boolean |
LockStoreImpl.isLocked(Data key) |
boolean |
LockStore.isLocked(Data key)
Check if a key is locked by any caller and thread ID.
|
boolean |
LockProxySupport.isLocked(NodeEngine nodeEngine,
Data key) |
boolean |
LockStoreProxy.isLockedBy(Data key,
String caller,
long threadId) |
boolean |
LockStoreImpl.isLockedBy(Data key,
String caller,
long threadId) |
boolean |
LockStore.isLockedBy(Data key,
String caller,
long threadId)
Check if a key is locked by a specific caller and thread ID.
|
boolean |
LockProxySupport.isLockedByCurrentThread(NodeEngine nodeEngine,
Data key) |
boolean |
LockStoreProxy.localLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStoreImpl.localLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStore.localLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime)
Lock a specific key on a local partition only.
|
boolean |
LockStoreProxy.lock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStoreImpl.lock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStore.lock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime)
Lock a specific key.
|
void |
LockProxySupport.lock(NodeEngine nodeEngine,
Data key) |
void |
LockProxySupport.lock(NodeEngine nodeEngine,
Data key,
long leaseTime) |
void |
LockProxySupport.lockInterruptly(NodeEngine nodeEngine,
Data key) |
void |
LockProxySupport.lockInterruptly(NodeEngine nodeEngine,
Data key,
long leaseTime) |
AwaitOperation |
LockStoreImpl.pollExpiredAwaitOp(Data key) |
void |
LockStoreImpl.removeAwait(Data key,
String conditionId,
String caller,
long threadId) |
boolean |
LockStoreProxy.shouldBlockReads(Data key) |
boolean |
LockStoreImpl.shouldBlockReads(Data key) |
boolean |
LockStore.shouldBlockReads(Data key)
Return whether the reads for the specific key should be blocked
(see
LockStore.txnLock(Data, String, long, long, long, boolean) ). |
void |
LockStoreImpl.signal(Data key,
String conditionId,
int maxSignalCount,
String objectName) |
boolean |
LockProxySupport.tryLock(NodeEngine nodeEngine,
Data key) |
boolean |
LockProxySupport.tryLock(NodeEngine nodeEngine,
Data key,
long timeout,
TimeUnit timeunit) |
boolean |
LockProxySupport.tryLock(NodeEngine nodeEngine,
Data key,
long timeout,
TimeUnit timeunit,
long leaseTime,
TimeUnit leaseTimeunit) |
boolean |
LockStoreProxy.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime,
boolean blockReads) |
boolean |
LockStoreImpl.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime,
boolean blockReads) |
boolean |
LockStore.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime,
boolean blockReads)
Lock a specific key for use inside a transaction.
|
boolean |
LockStoreProxy.unlock(Data key,
String caller,
long threadId,
long referenceId) |
boolean |
LockStoreImpl.unlock(Data key,
String caller,
long threadId,
long referenceId) |
boolean |
LockStore.unlock(Data key,
String caller,
long threadId,
long referenceId)
Unlock a specific key.
|
void |
LockProxySupport.unlock(NodeEngine nodeEngine,
Data key) |
Modifier and Type | Method and Description |
---|---|
void |
LockEvictionProcessor.process(EntryTaskScheduler<Data,Integer> scheduler,
Collection<ScheduledEntry<Data,Integer>> entries) |
void |
LockEvictionProcessor.process(EntryTaskScheduler<Data,Integer> scheduler,
Collection<ScheduledEntry<Data,Integer>> entries) |
Constructor and Description |
---|
ConditionKey(String name,
Data key,
String conditionId,
String uuid,
long threadId) |
LockWaitNotifyKey(ObjectNamespace namespace,
Data key) |
Constructor and Description |
---|
LockStoreImpl(LockService lockService,
ObjectNamespace name,
EntryTaskScheduler<Data,Integer> entryTaskScheduler,
int backupCount,
int asyncBackupCount) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractLockOperation.key |
Modifier and Type | Method and Description |
---|---|
Data |
AbstractLockOperation.getKey() |
Constructor and Description |
---|
AbstractLockOperation(ObjectNamespace namespace,
Data key,
long threadId) |
AbstractLockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long timeout) |
AbstractLockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long leaseTime,
long timeout) |
AwaitBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
String originalCaller) |
AwaitOperation(ObjectNamespace namespace,
Data key,
long threadId,
long timeout,
String conditionId) |
AwaitOperation(ObjectNamespace namespace,
Data key,
long threadId,
long timeout,
String conditionId,
long referenceId) |
BeforeAwaitBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
String originalCaller) |
BeforeAwaitOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId) |
BeforeAwaitOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
long referenceId) |
GetLockCountOperation(ObjectNamespace namespace,
Data key) |
GetRemainingLeaseTimeOperation(ObjectNamespace namespace,
Data key) |
IsLockedOperation(ObjectNamespace namespace,
Data key) |
IsLockedOperation(ObjectNamespace namespace,
Data key,
long threadId) |
LocalLockCleanupOperation(ObjectNamespace namespace,
Data key,
String uuid) |
LockBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
long leaseTime,
String originalCallerUuid) |
LockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long leaseTime,
long timeout) |
LockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long leaseTime,
long timeout,
long referenceId) |
SignalBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
boolean all) |
SignalOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
boolean all) |
UnlockBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String originalCallerUuid,
boolean force) |
UnlockIfLeaseExpiredOperation(ObjectNamespace namespace,
Data key,
int version) |
UnlockOperation(ObjectNamespace namespace,
Data key,
long threadId) |
UnlockOperation(ObjectNamespace namespace,
Data key,
long threadId,
boolean force) |
UnlockOperation(ObjectNamespace namespace,
Data key,
long threadId,
boolean force,
long referenceId) |
Modifier and Type | Class and Description |
---|---|
class |
com.hazelcast.internal.serialization.impl.HeapData
A
Data implementation where the content lives on the heap. |
Modifier and Type | Method and Description |
---|---|
Queue<Map.Entry<Data,Data>> |
TestOutbox.snapshotQueue()
Returns the queue to which snapshot is written.
|
Queue<Map.Entry<Data,Data>> |
TestOutbox.snapshotQueue()
Returns the queue to which snapshot is written.
|
Modifier and Type | Class and Description |
---|---|
class |
Packet
A Packet is a piece of data sent over the wire.
|
Modifier and Type | Method and Description |
---|---|
Data |
ObjectDataInput.readData() |
Modifier and Type | Method and Description |
---|---|
void |
ObjectDataOutput.writeData(Data data) |
Modifier and Type | Method and Description |
---|---|
protected Data |
AbstractDistributedObject.getNameAsPartitionAwareData() |
Data |
NodeEngine.toData(Object object)
Serializes an object to a
Data . |
protected Data |
AbstractDistributedObject.toData(Object object) |
Modifier and Type | Method and Description |
---|---|
protected int |
AbstractDistributedObject.getPartitionId(Data key) |
Modifier and Type | Method and Description |
---|---|
int |
IPartitionService.getPartitionId(Data key)
Returns the partition ID for a
Data key. |
Modifier and Type | Method and Description |
---|---|
<B extends Data> |
SerializationService.toData(Object obj)
Serializes an object to a
Data . |
<B extends Data> |
SerializationService.toData(Object obj,
PartitioningStrategy strategy)
Serializes an object to a
Data . |
Modifier and Type | Method and Description |
---|---|
static <C> Collection<Data> |
CollectionUtil.objectToDataCollection(Collection<C> collection,
SerializationService serializationService)
Converts a collection of any type to a collection of
Data . |
Modifier and Type | Method and Description |
---|---|
static <C> void |
CollectionUtil.objectToDataCollection(Collection<C> objectCollection,
Collection<Data> dataCollection,
SerializationService serializationService,
String errorMessage)
Converts a collection of any type to a collection of
Data . |
Modifier and Type | Method and Description |
---|---|
Data |
ReplicationEventObject.getKey()
Returns the key for the entry on which the event occurred.
|
Copyright © 2018 Hazelcast, Inc.. All rights reserved.