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.cardinality |
This package contains Cardinality Estimator functionality for Hazelcast.
|
com.hazelcast.client.cache.impl |
Hazelcast JSR-107 aka JCache implementation client side
|
com.hazelcast.client.cp.internal.session |
Contains client-side impl of the Raft proxy session manager
|
com.hazelcast.client.proxy |
This package contains client side proxy implementations of the different Hazelcast data structures
and operation types
|
com.hazelcast.client.spi.impl |
Provides util classes for the Hazelcast client SPI.
|
com.hazelcast.client.util |
This package contains some utility classes and the base implementations of the
loadbalancer implementations
|
com.hazelcast.core |
Provides core API interfaces/classes.
|
com.hazelcast.cp |
Contains public APIs of the CP subsystem
|
com.hazelcast.cp.internal |
Contains implementation of the CP subsystem
|
com.hazelcast.cp.internal.datastructures.atomiclong.proxy |
Contains
IAtomicLong functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.raft.impl |
Contains implementation classes of the Raft algorithm
|
com.hazelcast.cp.internal.session |
Contains service classes
for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.session |
Contains session abstractions of the CP subsystem
|
com.hazelcast.durableexecutor |
This package contains DurableExecutorService functionality for Hazelcast.
The DurableExecutorService extends the ExecutorService and provides additional methods like
executing tasks on a member who is owner of a specific key. |
com.hazelcast.internal.adapter |
Data structure adapters for Near Cache.
|
com.hazelcast.internal.dynamicconfig |
Classes related to Dynamic Configuration.
|
com.hazelcast.internal.journal |
This package contains supporting classes for data structure specific event journals.
|
com.hazelcast.internal.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.internal.util.futures |
Re-usable implementations of Futures.
|
com.hazelcast.map.impl.proxy |
Contains map proxy implementation and support classes.
|
com.hazelcast.mapreduce |
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the active Hazelcast cluster. |
com.hazelcast.mapreduce.impl.task |
This package contains the base implementation for a standard map reduce job.
|
com.hazelcast.ringbuffer |
Contains the API for the
Ringbuffer . |
com.hazelcast.ringbuffer.impl |
Contains the
Ringbuffer implementation classes. |
com.hazelcast.spi |
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
|
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.spi.impl.executionservice.impl |
Contains the implementation of the
InternalExecutionService . |
com.hazelcast.spi.impl.operationservice.impl |
Contains the code for the
InternalOperationService implementation. |
com.hazelcast.util.executor |
This package contains classes related to Util.Executor
|
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<V> |
ICache.getAndPutAsync(K key,
V value)
Asynchronously associates the specified value with the specified key in this cache,
returning an existing value if one existed.
|
ICompletableFuture<V> |
ICache.getAndPutAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Asynchronously associates the specified value with the specified key in this cache,
returning an existing value if one existed using a custom
ExpiryPolicy . |
ICompletableFuture<V> |
ICache.getAndRemoveAsync(K key)
Asynchronously removes the entry for a key and returns the previously assigned value or null
if no value was assigned.
|
ICompletableFuture<V> |
ICache.getAndReplaceAsync(K key,
V value)
Asynchronously replaces the assigned value of the given key by the specified value and returns
the previously assigned value.
|
ICompletableFuture<V> |
ICache.getAndReplaceAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Asynchronously replaces the assigned value of the given key by the specified value using a
custom
ExpiryPolicy and returns the previously assigned value. |
ICompletableFuture<V> |
ICache.getAsync(K key)
Asynchronously retrieves the mapped value of the given key using a custom
ExpiryPolicy . |
ICompletableFuture<V> |
ICache.getAsync(K key,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Asynchronously gets an entry from cache using a custom
ExpiryPolicy . |
ICompletableFuture<Void> |
ICache.putAsync(K key,
V value)
Asynchronously associates the specified value with the specified key in the cache.
|
ICompletableFuture<Void> |
ICache.putAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Asynchronously associates the specified value with the specified key in the cache using
a custom
ExpiryPolicy . |
ICompletableFuture<Boolean> |
ICache.putIfAbsentAsync(K key,
V value)
Asynchronously associates the specified key with the given value if and only if there is not yet
a mapping defined for the specified key.
|
ICompletableFuture<Boolean> |
ICache.putIfAbsentAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Asynchronously associates the specified key with the given value if and only if there is not yet
a mapping defined for the specified key.
|
ICompletableFuture<Boolean> |
ICache.removeAsync(K key)
Asynchronously removes the mapping for a key from this cache if it is present.
|
ICompletableFuture<Boolean> |
ICache.removeAsync(K key,
V oldValue)
Asynchronously removes the mapping for the given key if and only if the
currently mapped value equals to the value of oldValue.
|
ICompletableFuture<Boolean> |
ICache.replaceAsync(K key,
V value)
Asynchronously replaces the assigned value of the given key by the specified value.
|
ICompletableFuture<Boolean> |
ICache.replaceAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Asynchronously replaces the assigned value of the given key by the specified value
using a custom
ExpiryPolicy . |
ICompletableFuture<Boolean> |
ICache.replaceAsync(K key,
V oldValue,
V newValue)
Asynchronously replaces the currently assigned value for the given key with the specified
newValue if and only if the currently assigned value equals the value of
oldValue.
|
ICompletableFuture<Boolean> |
ICache.replaceAsync(K key,
V oldValue,
V newValue,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Asynchronously replaces the currently assigned value for the given key with the specified
newValue if and only if the currently assigned value equals the value of
oldValue using a custom
ExpiryPolicy . |
Modifier and Type | Method and Description |
---|---|
<K,V> ICompletableFuture |
AbstractCacheService.createCacheConfigOnAllMembersAsync(PreJoinCacheConfig<K,V> cacheConfig) |
<T> ICompletableFuture<ReadResultSet<T>> |
CacheProxy.readFromEventJournal(long startSequence,
int minSize,
int maxSize,
int partitionId,
Predicate<? super EventJournalCacheEvent<K,V>> predicate,
Projection<? super EventJournalCacheEvent<K,V>,? extends T> projection) |
ICompletableFuture<EventJournalInitialSubscriberState> |
CacheProxy.subscribeToEventJournal(int partitionId) |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Void> |
CardinalityEstimator.addAsync(Object obj)
Add a new object in the estimation set.
|
ICompletableFuture<Long> |
CardinalityEstimator.estimateAsync()
Estimates the cardinality of the aggregation so far.
|
Modifier and Type | Method and Description |
---|---|
<T> ICompletableFuture<ReadResultSet<T>> |
ClientCacheProxy.readFromEventJournal(long startSequence,
int minSize,
int maxSize,
int partitionId,
Predicate<? super EventJournalCacheEvent<K,V>> predicate,
Projection<? super EventJournalCacheEvent<K,V>,? extends T> projection) |
ICompletableFuture<EventJournalInitialSubscriberState> |
ClientCacheProxy.subscribeToEventJournal(int partitionId) |
Modifier and Type | Method and Description |
---|---|
protected ICompletableFuture<Object> |
ClientProxySessionManager.closeSession(RaftGroupId groupId,
Long sessionId) |
protected ICompletableFuture<Object> |
ClientProxySessionManager.heartbeat(RaftGroupId groupId,
long sessionId) |
Modifier and Type | Method and Description |
---|---|
Map<RaftGroupId,ICompletableFuture<Object>> |
ClientProxySessionManager.shutdown() |
Modifier and Type | Class and Description |
---|---|
class |
IExecutorDelegatingFuture<V>
An Abstract DelegatingFuture that can cancel a Runnable/Callable that is executed by an
IExecutorService . |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Long> |
ClientRingbufferProxy.addAllAsync(Collection<? extends E> collection,
OverflowPolicy overflowPolicy) |
ICompletableFuture<Long> |
ClientRingbufferProxy.addAsync(E item,
OverflowPolicy overflowPolicy) |
ICompletableFuture<V> |
NearCachedClientMapProxy.getAsync(K key) |
ICompletableFuture<V> |
ClientMapProxy.getAsync(K key) |
ICompletableFuture<V> |
ClientMapProxy.putAsync(K key,
V value) |
ICompletableFuture<V> |
ClientMapProxy.putAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<V> |
ClientMapProxy.putAsync(K key,
V value,
long ttl,
TimeUnit ttlUnit,
long maxIdle,
TimeUnit maxIdleUnit) |
protected ICompletableFuture<V> |
NearCachedClientMapProxy.putAsyncInternal(long ttl,
TimeUnit timeunit,
Long maxIdle,
TimeUnit maxIdleUnit,
Object key,
Object value) |
protected ICompletableFuture<V> |
ClientMapProxy.putAsyncInternal(long ttl,
TimeUnit timeunit,
Long maxIdle,
TimeUnit maxIdleUnit,
Object key,
Object value) |
<T> ICompletableFuture<ReadResultSet<T>> |
ClientMapProxy.readFromEventJournal(long startSequence,
int minSize,
int maxSize,
int partitionId,
Predicate<? super EventJournalMapEvent<K,V>> predicate,
Projection<? super EventJournalMapEvent<K,V>,? extends T> projection) |
ICompletableFuture<ReadResultSet<E>> |
ClientRingbufferProxy.readManyAsync(long startSequence,
int minCount,
int maxCount,
IFunction<E,Boolean> filter) |
ICompletableFuture<V> |
ClientMapProxy.removeAsync(K key) |
protected ICompletableFuture<V> |
NearCachedClientMapProxy.removeAsyncInternal(Object key) |
protected ICompletableFuture<V> |
ClientMapProxy.removeAsyncInternal(Object key) |
ICompletableFuture<Void> |
ClientMapProxy.setAsync(K key,
V value) |
ICompletableFuture<Void> |
ClientMapProxy.setAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<Void> |
ClientMapProxy.setAsync(K key,
V value,
long ttl,
TimeUnit ttlUnit,
long maxIdle,
TimeUnit maxIdleUnit) |
protected ICompletableFuture<Void> |
NearCachedClientMapProxy.setAsyncInternal(long ttl,
TimeUnit timeunit,
Long maxIdle,
TimeUnit maxIdleUnit,
Object key,
Object value) |
protected ICompletableFuture<Void> |
ClientMapProxy.setAsyncInternal(long ttl,
TimeUnit timeunit,
Long maxIdle,
TimeUnit maxIdleUnit,
Object key,
Object value) |
ICompletableFuture |
ClientMapProxy.submitToKey(K key,
EntryProcessor entryProcessor) |
ICompletableFuture |
NearCachedClientMapProxy.submitToKeyInternal(Object key,
EntryProcessor entryProcessor) |
ICompletableFuture |
ClientMapProxy.submitToKeyInternal(Object key,
EntryProcessor entryProcessor) |
ICompletableFuture<Map<K,Object>> |
ClientMapProxy.submitToKeys(Set<K> keys,
EntryProcessor entryProcessor)
|
ICompletableFuture<EventJournalInitialSubscriberState> |
ClientMapProxy.subscribeToEventJournal(int partitionId) |
Modifier and Type | Class and Description |
---|---|
class |
ClientInvocationFuture |
Modifier and Type | Class and Description |
---|---|
class |
ClientDelegatingFuture<V>
The Client Delegating Future is used to delegate
ClientInvocationFuture to a user type to be used with andThen() or
get() . |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<E> |
Pipeline.add(ICompletableFuture<E> future)
Adds a future to this Pipeline or blocks until there is capacity to add the future to the pipeline.
|
ICompletableFuture<Long> |
IAtomicLong.addAndGetAsync(long delta)
Atomically adds the given value to the current value.
|
ICompletableFuture<E> |
IAtomicReference.alterAndGetAsync(IFunction<E,E> function)
Alters the currently stored reference by applying a function on it and
gets the result.
|
ICompletableFuture<Long> |
IAtomicLong.alterAndGetAsync(IFunction<Long,Long> function)
Alters the currently stored value by applying a function on it and gets
the result.
|
ICompletableFuture<Void> |
IAtomicReference.alterAsync(IFunction<E,E> function)
Alters the currently stored reference by applying a function on it.
|
ICompletableFuture<Void> |
IAtomicLong.alterAsync(IFunction<Long,Long> function)
Alters the currently stored value by applying a function on it.
|
<R> ICompletableFuture<R> |
IAtomicReference.applyAsync(IFunction<E,R> function)
Applies a function on the value, the actual stored value will not
change.
|
<R> ICompletableFuture<R> |
IAtomicLong.applyAsync(IFunction<Long,R> function)
Applies a function on the value, the actual stored value will not
change.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncAddAndGet(long delta)
Deprecated.
Atomically adds the given value to the current value.
|
ICompletableFuture<Void> |
AsyncAtomicReference.asyncAlter(IFunction<E,E> function)
Deprecated.
Alters the currently stored reference by applying a function on it.
|
ICompletableFuture<Void> |
AsyncAtomicLong.asyncAlter(IFunction<Long,Long> function)
Deprecated.
Alters the currently stored value by applying a function on it.
|
ICompletableFuture<E> |
AsyncAtomicReference.asyncAlterAndGet(IFunction<E,E> function)
Deprecated.
Alters the currently stored reference by applying a function on it and gets the result.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncAlterAndGet(IFunction<Long,Long> function)
Deprecated.
Alters the currently stored value by applying a function on it and gets the result.
|
<R> ICompletableFuture<R> |
AsyncAtomicReference.asyncApply(IFunction<E,R> function)
Deprecated.
Applies a function on the value, the actual stored value will not change.
|
<R> ICompletableFuture<R> |
AsyncAtomicLong.asyncApply(IFunction<Long,R> function)
Deprecated.
Applies a function on the value, the actual stored value will not change.
|
ICompletableFuture<Void> |
AsyncAtomicReference.asyncClear()
Deprecated.
Clears the current stored reference.
|
ICompletableFuture<Boolean> |
AsyncAtomicReference.asyncCompareAndSet(E expect,
E update)
Deprecated.
Atomically sets the value to the given updated value
only if the current value
== the expected value. |
ICompletableFuture<Boolean> |
AsyncAtomicLong.asyncCompareAndSet(long expect,
long update)
Deprecated.
Atomically sets the value to the given updated value
only if the current value
== the expected value. |
ICompletableFuture<Boolean> |
AsyncAtomicReference.asyncContains(E value)
Deprecated.
Checks if the reference contains the value.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncDecrementAndGet()
Deprecated.
Atomically decrements the current value by one.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncGet()
Deprecated.
Gets the current value.
|
ICompletableFuture<E> |
AsyncAtomicReference.asyncGet()
Deprecated.
Gets the current value.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncGetAndAdd(long delta)
Deprecated.
Atomically adds the given value to the current value.
|
ICompletableFuture<E> |
AsyncAtomicReference.asyncGetAndAlter(IFunction<E,E> function)
Deprecated.
Alters the currently stored reference by applying a function on it on and gets the old value.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncGetAndAlter(IFunction<Long,Long> function)
Deprecated.
Alters the currently stored value by applying a function on it on and gets the old value.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncGetAndIncrement()
Deprecated.
Atomically increments the current value by one.
|
ICompletableFuture<E> |
AsyncAtomicReference.asyncGetAndSet(E newValue)
Deprecated.
Gets the value and sets the new value.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncGetAndSet(long newValue)
Deprecated.
Atomically sets the given value and returns the old value.
|
ICompletableFuture<Long> |
AsyncAtomicLong.asyncIncrementAndGet()
Deprecated.
Atomically increments the current value by one.
|
ICompletableFuture<Boolean> |
AsyncAtomicReference.asyncIsNull()
Deprecated.
Checks if the stored reference is null.
|
ICompletableFuture<Void> |
AsyncAtomicReference.asyncSet(E newValue)
Deprecated.
Atomically sets the given value.
|
ICompletableFuture<Void> |
AsyncAtomicLong.asyncSet(long newValue)
Deprecated.
Atomically sets the given value.
|
ICompletableFuture<E> |
AsyncAtomicReference.asyncSetAndGet(E update)
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose.
|
ICompletableFuture<Void> |
IAtomicReference.clearAsync()
Clears the current stored reference.
|
ICompletableFuture<Boolean> |
IAtomicReference.compareAndSetAsync(E expect,
E update)
Atomically sets the value to the given updated value only if the
current value
== the expected value. |
ICompletableFuture<Boolean> |
IAtomicLong.compareAndSetAsync(long expect,
long update)
Atomically sets the value to the given updated value
only if the current value
== the expected value. |
ICompletableFuture<Boolean> |
IAtomicReference.containsAsync(E expected)
Checks if the reference contains the value.
|
ICompletableFuture<Long> |
IAtomicLong.decrementAndGetAsync()
Atomically decrements the current value by one.
|
ICompletableFuture<Long> |
IAtomicLong.getAndAddAsync(long delta)
Atomically adds the given value to the current value.
|
ICompletableFuture<E> |
IAtomicReference.getAndAlterAsync(IFunction<E,E> function)
Alters the currently stored reference by applying a function on it on
and gets the old value.
|
ICompletableFuture<Long> |
IAtomicLong.getAndAlterAsync(IFunction<Long,Long> function)
Alters the currently stored value by applying a function on it on and
gets the old value.
|
ICompletableFuture<Long> |
IAtomicLong.getAndIncrementAsync()
Atomically increments the current value by one.
|
ICompletableFuture<E> |
IAtomicReference.getAndSetAsync(E newValue)
Gets the value and sets the new value.
|
ICompletableFuture<Long> |
IAtomicLong.getAndSetAsync(long newValue)
Atomically sets the given value and returns the old value.
|
ICompletableFuture<E> |
IAtomicReference.getAsync()
Gets the current value.
|
ICompletableFuture<Long> |
IAtomicLong.getAsync()
Gets the current value.
|
ICompletableFuture<V> |
IMap.getAsync(K key)
Asynchronously gets the given key.
|
ICompletableFuture<Long> |
IAtomicLong.incrementAndGetAsync()
Atomically increments the current value by one.
|
ICompletableFuture<Boolean> |
IAtomicReference.isNullAsync()
Checks if the stored reference is
null . |
ICompletableFuture<V> |
IMap.putAsync(K key,
V value)
Asynchronously puts the given key and value.
|
ICompletableFuture<V> |
IMap.putAsync(K key,
V value,
long ttl,
TimeUnit ttlUnit)
Asynchronously puts the given key and value into this map with a given TTL (time to live) value.
|
ICompletableFuture<V> |
IMap.putAsync(K key,
V value,
long ttl,
TimeUnit ttlUnit,
long maxIdle,
TimeUnit maxIdleUnit)
Asynchronously puts the given key and value into this map with a given TTL (time to live) value and max idle time value.
|
ICompletableFuture<V> |
IMap.removeAsync(K key)
Asynchronously removes the given key, returning an
ICompletableFuture on which
the caller can provide an ExecutionCallback to be invoked upon remove operation
completion or block waiting for the operation to complete with Future.get() . |
ICompletableFuture<Void> |
IAtomicReference.setAsync(E newValue)
Atomically sets the given value.
|
ICompletableFuture<Void> |
IMap.setAsync(K key,
V value)
Asynchronously puts the given key and value.
|
ICompletableFuture<Void> |
IMap.setAsync(K key,
V value,
long ttl,
TimeUnit ttlUnit)
Asynchronously puts an entry into this map with a given TTL (time to live) value,
without returning the old value (which is more efficient than
put() ). |
ICompletableFuture<Void> |
IMap.setAsync(K key,
V value,
long ttl,
TimeUnit ttlUnit,
long maxIdle,
TimeUnit maxIdleUnit)
Asynchronously puts an entry into this map with a given TTL (time to live) value and max idle time value.
|
ICompletableFuture<Void> |
IAtomicLong.setAsync(long newValue)
Atomically sets the given value.
|
ICompletableFuture |
IMap.submitToKey(K key,
EntryProcessor entryProcessor)
Applies the user defined
EntryProcessor to the entry mapped by the key . |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<E> |
Pipeline.add(ICompletableFuture<E> future)
Adds a future to this Pipeline or blocks until there is capacity to add the future to the pipeline.
|
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Void> |
CPSubsystemManagementService.forceDestroyCPGroup(String groupName)
Unconditionally destroys the given active CP group without using
the Raft algorithm mechanics.
|
ICompletableFuture<CPGroup> |
CPSubsystemManagementService.getCPGroup(String name)
Returns the active CP group with the given name.
|
ICompletableFuture<Collection<CPGroupId>> |
CPSubsystemManagementService.getCPGroupIds()
Returns all active CP group ids.
|
ICompletableFuture<Collection<CPMember>> |
CPSubsystemManagementService.getCPMembers()
Returns the current list of CP members
|
ICompletableFuture<Void> |
CPSubsystemManagementService.promoteToCPMember()
Promotes the local Hazelcast member to a CP member.
|
ICompletableFuture<Void> |
CPSubsystemManagementService.removeCPMember(String cpMemberUuid)
Removes the given unreachable CP member from the active CP members list
and all CP groups it belongs to.
|
ICompletableFuture<Void> |
CPSubsystemManagementService.restart()
Wipes & resets the whole CP subsystem and initializes it
as if the Hazelcast cluster is starting up initially.
|
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<RaftGroupId> |
RaftInvocationManager.createRaftGroup(String groupName) |
ICompletableFuture<RaftGroupId> |
RaftInvocationManager.createRaftGroup(String groupName,
int groupSize) |
ICompletableFuture<Void> |
RaftService.forceDestroyCPGroup(String groupName)
this method is idempotent
|
ICompletableFuture<Collection<CPGroupId>> |
RaftService.getAllCPGroupIds() |
ICompletableFuture<CPGroup> |
RaftService.getCPGroup(CPGroupId groupId) |
ICompletableFuture<CPGroup> |
RaftService.getCPGroup(String name) |
ICompletableFuture<Collection<CPGroupId>> |
RaftService.getCPGroupIds() |
ICompletableFuture<Collection<CPMember>> |
RaftService.getCPMembers() |
ICompletableFuture<Void> |
RaftService.promoteToCPMember() |
ICompletableFuture<Void> |
RaftService.removeCPMember(String cpMemberUuid) |
ICompletableFuture<Void> |
RaftService.restart() |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Long> |
RaftAtomicLongProxy.localGetAsync(QueryPolicy queryPolicy) |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture |
RaftNodeImpl.query(Object operation,
QueryPolicy queryPolicy) |
ICompletableFuture |
RaftNode.query(Object operation,
QueryPolicy queryPolicy)
Executes the given operation on Raft group depending
on the
QueryPolicy |
ICompletableFuture |
RaftNodeImpl.replicate(Object operation) |
ICompletableFuture |
RaftNode.replicate(Object operation)
Replicates the given operation to the Raft group.
|
ICompletableFuture |
RaftNodeImpl.replicateMembershipChange(Endpoint member,
MembershipChangeMode mode) |
ICompletableFuture |
RaftNode.replicateMembershipChange(Endpoint member,
MembershipChangeMode mode)
Replicates the membership change to the Raft group.
|
ICompletableFuture |
RaftNodeImpl.replicateMembershipChange(Endpoint member,
MembershipChangeMode mode,
long groupMembersCommitIndex) |
ICompletableFuture |
RaftNode.replicateMembershipChange(Endpoint member,
MembershipChangeMode mode,
long groupMembersCommitIndex)
Replicates the membership change to the Raft group, if expected members
commit index is equal to the actual one stored in Raft state.
|
Modifier and Type | Method and Description |
---|---|
protected ICompletableFuture<Object> |
ProxySessionManagerService.closeSession(RaftGroupId groupId,
Long sessionId) |
protected abstract ICompletableFuture<Object> |
AbstractProxySessionManager.closeSession(RaftGroupId groupId,
Long sessionId)
Closes the given session on the Raft group
|
ICompletableFuture<Boolean> |
RaftSessionService.forceCloseSession(String groupName,
long sessionId) |
ICompletableFuture<Collection<CPSession>> |
RaftSessionService.getAllSessions(String groupName) |
protected ICompletableFuture<Object> |
ProxySessionManagerService.heartbeat(RaftGroupId groupId,
long sessionId) |
protected abstract ICompletableFuture<Object> |
AbstractProxySessionManager.heartbeat(RaftGroupId groupId,
long sessionId)
Commits a heartbeat for the session on the Raft group
|
Modifier and Type | Method and Description |
---|---|
Map<RaftGroupId,ICompletableFuture<Object>> |
AbstractProxySessionManager.shutdown()
Invokes a shutdown call on server to close all existing sessions.
|
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Boolean> |
CPSessionManagementService.forceCloseSession(String groupName,
long sessionId)
If a Hazelcast instance that owns a CP session crashes, its CP session
is not terminated immediately.
|
ICompletableFuture<Collection<CPSession>> |
CPSessionManagementService.getAllSessions(String groupName)
Returns a non-null collection of CP sessions that are currently active
in the given CP group.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DurableExecutorServiceFuture<V>
A Future where one can obtain the task ID for tracking the response.
|
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Boolean> |
IMapDataStructureAdapter.deleteAsync(K key) |
ICompletableFuture<Boolean> |
TransactionalMapDataStructureAdapter.deleteAsync(K key) |
ICompletableFuture<Boolean> |
DataStructureAdapter.deleteAsync(K key) |
ICompletableFuture<Boolean> |
ReplicatedMapDataStructureAdapter.deleteAsync(K key) |
ICompletableFuture<Boolean> |
ICacheDataStructureAdapter.deleteAsync(K key) |
ICompletableFuture<V> |
IMapDataStructureAdapter.getAsync(K key) |
ICompletableFuture<V> |
TransactionalMapDataStructureAdapter.getAsync(K key) |
ICompletableFuture<V> |
DataStructureAdapter.getAsync(K key) |
ICompletableFuture<V> |
ReplicatedMapDataStructureAdapter.getAsync(K key) |
ICompletableFuture<V> |
ICacheDataStructureAdapter.getAsync(K key) |
ICompletableFuture<V> |
IMapDataStructureAdapter.putAsync(K key,
V value) |
ICompletableFuture<V> |
TransactionalMapDataStructureAdapter.putAsync(K key,
V value) |
ICompletableFuture<V> |
DataStructureAdapter.putAsync(K key,
V value) |
ICompletableFuture<V> |
ReplicatedMapDataStructureAdapter.putAsync(K key,
V value) |
ICompletableFuture<V> |
ICacheDataStructureAdapter.putAsync(K key,
V value) |
ICompletableFuture<V> |
IMapDataStructureAdapter.putAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<V> |
TransactionalMapDataStructureAdapter.putAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<V> |
DataStructureAdapter.putAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<V> |
ReplicatedMapDataStructureAdapter.putAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<V> |
ICacheDataStructureAdapter.putAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<V> |
IMapDataStructureAdapter.putAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<V> |
TransactionalMapDataStructureAdapter.putAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<V> |
DataStructureAdapter.putAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<V> |
ReplicatedMapDataStructureAdapter.putAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<V> |
ICacheDataStructureAdapter.putAsync(K key,
V value,
long time,
TimeUnit unit) |
ICompletableFuture<Boolean> |
IMapDataStructureAdapter.putIfAbsentAsync(K key,
V value) |
ICompletableFuture<Boolean> |
TransactionalMapDataStructureAdapter.putIfAbsentAsync(K key,
V value) |
ICompletableFuture<Boolean> |
DataStructureAdapter.putIfAbsentAsync(K key,
V value) |
ICompletableFuture<Boolean> |
ReplicatedMapDataStructureAdapter.putIfAbsentAsync(K key,
V value) |
ICompletableFuture<Boolean> |
ICacheDataStructureAdapter.putIfAbsentAsync(K key,
V value) |
ICompletableFuture<V> |
IMapDataStructureAdapter.removeAsync(K key) |
ICompletableFuture<V> |
TransactionalMapDataStructureAdapter.removeAsync(K key) |
ICompletableFuture<V> |
DataStructureAdapter.removeAsync(K key) |
ICompletableFuture<V> |
ReplicatedMapDataStructureAdapter.removeAsync(K key) |
ICompletableFuture<V> |
ICacheDataStructureAdapter.removeAsync(K key) |
ICompletableFuture<Void> |
IMapDataStructureAdapter.setAsync(K key,
V value) |
ICompletableFuture<Void> |
TransactionalMapDataStructureAdapter.setAsync(K key,
V value) |
ICompletableFuture<Void> |
DataStructureAdapter.setAsync(K key,
V value) |
ICompletableFuture<Void> |
ReplicatedMapDataStructureAdapter.setAsync(K key,
V value) |
ICompletableFuture<Void> |
ICacheDataStructureAdapter.setAsync(K key,
V value) |
ICompletableFuture<Void> |
IMapDataStructureAdapter.setAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<Void> |
TransactionalMapDataStructureAdapter.setAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<Void> |
DataStructureAdapter.setAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<Void> |
ReplicatedMapDataStructureAdapter.setAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<Void> |
ICacheDataStructureAdapter.setAsync(K key,
V value,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
ICompletableFuture<Void> |
IMapDataStructureAdapter.setAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<Void> |
TransactionalMapDataStructureAdapter.setAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<Void> |
DataStructureAdapter.setAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<Void> |
ReplicatedMapDataStructureAdapter.setAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<Void> |
ICacheDataStructureAdapter.setAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Object> |
ClusterWideConfigurationService.broadcastConfigAsync(IdentifiedDataSerializable config) |
Modifier and Type | Method and Description |
---|---|
<T> ICompletableFuture<ReadResultSet<T>> |
EventJournalReader.readFromEventJournal(long startSequence,
int minSize,
int maxSize,
int partitionId,
Predicate<? super E> predicate,
Projection<? super E,? extends T> projection)
Reads from the event journal.
|
ICompletableFuture<EventJournalInitialSubscriberState> |
EventJournalReader.subscribeToEventJournal(int partitionId)
Subscribe to the event journal for this reader and a specific partition ID.
|
Modifier and Type | Class and Description |
---|---|
class |
SimpleCompletableFuture<T>
Generic implementation of
InternalCompletableFuture . |
class |
SimpleCompletedFuture<E>
Generic implementation of a completed
InternalCompletableFuture . |
Modifier and Type | Method and Description |
---|---|
static ICompletableFuture<Object> |
InvocationUtil.invokeOnStableClusterSerial(NodeEngine nodeEngine,
Supplier<? extends Operation> operationSupplier,
int maxRetries)
Invoke operation on all cluster members.
|
Modifier and Type | Class and Description |
---|---|
class |
ChainingFuture<T>
Iterates over supplied
ICompletableFuture serially. |
Constructor and Description |
---|
ChainingFuture(Iterator<ICompletableFuture<T>> futuresToChain,
Executor executor,
ChainingFuture.ExceptionHandler exceptionHandler,
ILogger logger) |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<V> |
MapProxyImpl.getAsync(K key) |
ICompletableFuture<V> |
MapProxyImpl.putAsync(K key,
V value) |
ICompletableFuture<V> |
MapProxyImpl.putAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<V> |
MapProxyImpl.putAsync(K key,
V value,
long ttl,
TimeUnit ttlUnit,
long maxIdle,
TimeUnit maxIdleUnit) |
<T> ICompletableFuture<ReadResultSet<T>> |
MapProxyImpl.readFromEventJournal(long startSequence,
int minSize,
int maxSize,
int partitionId,
Predicate<? super EventJournalMapEvent<K,V>> predicate,
Projection<? super EventJournalMapEvent<K,V>,? extends T> projection)
Reads from the event journal.
|
ICompletableFuture<V> |
MapProxyImpl.removeAsync(K key) |
ICompletableFuture<Void> |
MapProxyImpl.setAsync(K key,
V value) |
ICompletableFuture<Void> |
MapProxyImpl.setAsync(K key,
V value,
long ttl,
TimeUnit timeunit) |
ICompletableFuture<Void> |
MapProxyImpl.setAsync(K key,
V value,
long ttl,
TimeUnit ttlUnit,
long maxIdle,
TimeUnit maxIdleUnit) |
ICompletableFuture |
MapProxyImpl.submitToKey(K key,
EntryProcessor entryProcessor) |
ICompletableFuture<Map<K,Object>> |
MapProxyImpl.submitToKeys(Set<K> keys,
EntryProcessor entryProcessor)
|
ICompletableFuture<Map<K,Object>> |
NearCachedMapProxyImpl.submitToKeysInternal(Set<K> keys,
Set<Data> dataKeys,
EntryProcessor entryProcessor) |
ICompletableFuture<EventJournalInitialSubscriberState> |
MapProxyImpl.subscribeToEventJournal(int partitionId) |
Modifier and Type | Interface and Description |
---|---|
interface |
JobCompletableFuture<V>
Deprecated.
MapReduce is deprecated and will be removed in 4.0.
For map aggregations, you can use
Aggregator on IMap.
For general data processing, it is superseded by Hazelcast Jet. |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<V> |
TrackableJob.getCompletableFuture()
Deprecated.
Returns the
ICompletableFuture to add callbacks
or wait for the resulting value of the tracked job. |
Modifier and Type | Class and Description |
---|---|
class |
TrackableJobFuture<V>
This is the node based implementation of the job's reactive
ICompletableFuture
and is returned to the users codebase. |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<V> |
TrackableJobFuture.getCompletableFuture() |
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Long> |
Ringbuffer.addAllAsync(Collection<? extends E> collection,
OverflowPolicy overflowPolicy)
Adds all the items of a collection to the tail of the Ringbuffer.
|
ICompletableFuture<Long> |
Ringbuffer.addAsync(E item,
OverflowPolicy overflowPolicy)
Asynchronously writes an item with a configurable
OverflowPolicy . |
ICompletableFuture<ReadResultSet<E>> |
Ringbuffer.readManyAsync(long startSequence,
int minCount,
int maxCount,
IFunction<E,Boolean> filter)
Reads a batch of items from the Ringbuffer.
|
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Long> |
RingbufferProxy.addAllAsync(Collection<? extends E> collection,
OverflowPolicy overflowPolicy) |
ICompletableFuture<Long> |
RingbufferProxy.addAsync(E item,
OverflowPolicy overflowPolicy) |
ICompletableFuture<ReadResultSet<E>> |
RingbufferProxy.readManyAsync(long startSequence,
int minCount,
int maxCount,
IFunction<E,Boolean> filter) |
Modifier and Type | Interface and Description |
---|---|
interface |
InternalCompletableFuture<E>
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
Modifier and Type | Method and Description |
---|---|
<V> ICompletableFuture<V> |
ExecutionService.asCompletableFuture(Future<V> future) |
<T> ICompletableFuture<Map<Integer,T>> |
OperationService.invokeOnAllPartitionsAsync(String serviceName,
OperationFactory operationFactory)
Invokes a set of operations on selected set of all partitions in an async way.
|
<T> ICompletableFuture<Map<Integer,T>> |
OperationService.invokeOnPartitionsAsync(String serviceName,
OperationFactory operationFactory,
Collection<Integer> partitions)
Invokes a set of operations on selected set of partitions in an async way.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCompletableFuture<V>
A base
ICompletableFuture implementation that may be explicitly completed by setting its
value through setResult. |
class |
AbstractInvocationFuture<V>
Custom implementation of
CompletableFuture . |
Modifier and Type | Method and Description |
---|---|
<V> ICompletableFuture<V> |
ExecutionServiceImpl.asCompletableFuture(Future<V> future) |
Modifier and Type | Method and Description |
---|---|
<T> ICompletableFuture<Map<Integer,T>> |
OperationServiceImpl.invokeOnAllPartitionsAsync(String serviceName,
OperationFactory operationFactory) |
<T> ICompletableFuture<Map<Integer,T>> |
OperationServiceImpl.invokeOnPartitionsAsync(String serviceName,
OperationFactory operationFactory,
Collection<Integer> partitions) |
Modifier and Type | Class and Description |
---|---|
class |
CompletableFutureTask<V> |
class |
CompletedFuture<V> |
class |
DelegatingFuture<V>
A
InternalCompletableFuture implementation that delegates the real logic to an underlying
InternalCompletableFuture and decorates it with additional behavior:
change the returned value by setting the result
always deserializing the content
caching the deserialized content so that a deserialization only happens once. |
Modifier and Type | Method and Description |
---|---|
protected ICompletableFuture |
DelegatingFuture.getFuture() |
Copyright © 2019 Hazelcast, Inc.. All Rights Reserved.