Package | Description |
---|---|
com.hazelcast.client.impl.protocol.template |
Modifier and Type | Method and Description |
---|---|
void |
SemaphoreCodecTemplate.acquire(String name,
int permits)
Acquires the given number of permits if they are available, and returns immediately, reducing the number of
available permits by the given amount.
|
Object |
ListCodecTemplate.add(String name,
Data value)
Appends the specified element to the end of this list (optional operation).
|
Object |
SetCodecTemplate.add(String name,
Data value)
Adds the specified element to this set if it is not already present (optional operation).
|
Object |
RingbufferCodecTemplate.add(String name,
int overflowPolicy,
Data value)
Adds an item to the tail of the Ringbuffer.
|
Object |
TransactionalSetCodecTemplate.add(String name,
String txnId,
long threadId,
Data item)
Add new item to transactional set.
|
Object |
TransactionalListCodecTemplate.add(String name,
String txnId,
long threadId,
Data item)
Adds a new item to the transactional list.
|
Object |
ListCodecTemplate.addAll(String name,
List<Data> valueList)
Appends all of the elements in the specified collection to the end of this list, in the order that they are
returned by the specified collection's iterator (optional operation).
|
Object |
QueueCodecTemplate.addAll(String name,
List<Data> dataList)
Adds all of the elements in the specified collection to this collection (optional operation).The behavior of this
operation is undefined if the specified collection is modified while the operation is in progress.
|
Object |
SetCodecTemplate.addAll(String name,
List<Data> valueList)
Adds all of the elements in the specified collection to this set if they're not already present
(optional operation).
|
Object |
RingbufferCodecTemplate.addAll(String name,
List<Data> valueList,
int overflowPolicy)
Adds all the items of a collection to the tail of the Ringbuffer.
|
Object |
ListCodecTemplate.addAllWithIndex(String name,
int index,
List<Data> valueList)
Inserts all of the elements in the specified collection into this list at the specified position (optional operation).
|
Object |
AtomicLongCodecTemplate.addAndGet(String name,
long delta)
Atomically adds the given value to the current value.
|
Object |
ClientMessageTemplate.addDistributedObjectListener(boolean localOnly) |
Object |
ReplicatedMapCodecTemplate.addEntryListener(String name,
boolean localOnly)
Adds an entry listener for this map.
|
Object |
CacheCodecTemplate.addEntryListener(String name,
boolean localOnly) |
Object |
MultiMapCodecTemplate.addEntryListener(String name,
boolean includeValue,
boolean localOnly)
Adds an entry listener for this multimap.
|
Object |
MapCodecTemplate.addEntryListener(String name,
boolean includeValue,
int listenerFlags,
boolean localOnly)
Adds a MapListener for this map.
|
Object |
ReplicatedMapCodecTemplate.addEntryListenerToKey(String name,
Data key,
boolean localOnly)
Adds the specified entry listener for the specified key.
|
Object |
MultiMapCodecTemplate.addEntryListenerToKey(String name,
Data key,
boolean includeValue,
boolean localOnly)
Adds the specified entry listener for the specified key.The listener will be notified for all
add/remove/update/evict events for the specified key only.
|
Object |
MapCodecTemplate.addEntryListenerToKey(String name,
Data key,
boolean includeValue,
int listenerFlags,
boolean localOnly)
Adds a MapListener for this map.
|
Object |
ReplicatedMapCodecTemplate.addEntryListenerToKeyWithPredicate(String name,
Data key,
Data predicate,
boolean localOnly)
Adds an continuous entry listener for this map.
|
Object |
MapCodecTemplate.addEntryListenerToKeyWithPredicate(String name,
Data key,
Data predicate,
boolean includeValue,
int listenerFlags,
boolean localOnly)
Adds a MapListener for this map.
|
Object |
ReplicatedMapCodecTemplate.addEntryListenerWithPredicate(String name,
Data predicate,
boolean localOnly)
Adds an continuous entry listener for this map.
|
Object |
MapCodecTemplate.addEntryListenerWithPredicate(String name,
Data predicate,
boolean includeValue,
int listenerFlags,
boolean localOnly)
Adds an continuous entry listener for this map.
|
void |
MapCodecTemplate.addIndex(String name,
String attribute,
boolean ordered)
Adds an index to this map for the specified entries so that queries can run faster.If you are querying your values
mostly based on age and active then you should consider indexing these fields.
|
Object |
MapCodecTemplate.addInterceptor(String name,
Data interceptor)
Adds an interceptor for this map.
|
Object |
CacheCodecTemplate.addInvalidationListener(String name,
boolean localOnly) |
Object |
EnterpriseMapCodecTemplate.addListener(String listenerName,
boolean localOnly) |
Object |
ListCodecTemplate.addListener(String name,
boolean includeValue,
boolean localOnly)
Adds an item listener for this collection.
|
Object |
QueueCodecTemplate.addListener(String name,
boolean includeValue,
boolean localOnly)
Adds an listener for this collection.
|
Object |
SetCodecTemplate.addListener(String name,
boolean includeValue,
boolean localOnly)
Adds an item listener for this collection.
|
Object |
ClientMessageTemplate.addMembershipListener(boolean localOnly) |
Object |
TopicCodecTemplate.addMessageListener(String name,
boolean localOnly)
Subscribes to this topic.
|
Object |
ReplicatedMapCodecTemplate.addNearCacheEntryListener(String name,
boolean includeValue,
boolean localOnly) |
Object |
MapCodecTemplate.addNearCacheEntryListener(String name,
int listenerFlags,
boolean localOnly)
Adds an entry listener for this map.
|
Object |
ClientMessageTemplate.addPartitionLostListener(boolean localOnly) |
Object |
CacheCodecTemplate.addPartitionLostListener(String name,
boolean localOnly)
Adds a CachePartitionLostListener.
|
Object |
MapCodecTemplate.addPartitionLostListener(String name,
boolean localOnly)
Adds a MapPartitionLostListener.
|
void |
ListCodecTemplate.addWithIndex(String name,
int index,
Data value)
Inserts the specified element at the specified position in this list (optional operation).
|
void |
AtomicReferenceCodecTemplate.alter(String name,
Data function)
Alters the currently stored reference by applying a function on it.
|
void |
AtomicLongCodecTemplate.alter(String name,
Data function)
Alters the currently stored value by applying a function on it.
|
Object |
AtomicReferenceCodecTemplate.alterAndGet(String name,
Data function)
Alters the currently stored reference by applying a function on it and gets the result.
|
Object |
AtomicLongCodecTemplate.alterAndGet(String name,
Data function)
Alters the currently stored value by applying a function on it and gets the result.
|
Object |
AtomicReferenceCodecTemplate.apply(String name,
Data function)
Applies a function on the value, the actual stored value will not change.
|
Object |
AtomicLongCodecTemplate.apply(String name,
Data function)
Applies a function on the value, the actual stored value will not change.
|
Object |
ClientMessageTemplate.authentication(String username,
String password,
String uuid,
String ownerUuid,
boolean isOwnerConnection,
String clientType,
byte serializationVersion) |
Object |
ClientMessageTemplate.authenticationCustom(Data credentials,
String uuid,
String ownerUuid,
boolean isOwnerConnection,
String clientType,
byte serializationVersion) |
Object |
SemaphoreCodecTemplate.availablePermits(String name)
Returns the current number of permits currently available in this semaphore.
|
Object |
CountdownLatchCodecTemplate.await(String name,
long timeout)
Causes the current thread to wait until the latch has counted down to zero, or an exception is thrown, or the
specified waiting time elapses.
|
Object |
ConditionCodecTemplate.await(String name,
long threadId,
long timeout,
String lockName)
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
|
void |
ConditionCodecTemplate.beforeAwait(String name,
long threadId,
String lockName)
Causes the current thread to wait until it is signalled or Thread#interrupt interrupted.
|
Object |
MapReduceCodecTemplate.cancel(String name,
String jobId) |
Object |
ExecutorServiceCodecTemplate.cancelOnAddress(String uuid,
Address address,
boolean interrupt) |
Object |
ExecutorServiceCodecTemplate.cancelOnPartition(String uuid,
int partitionId,
boolean interrupt) |
Object |
RingbufferCodecTemplate.capacity(String name)
Returns the capacity of this Ringbuffer.
|
void |
ReplicatedMapCodecTemplate.clear(String name)
The clear operation wipes data out of the replicated maps.It is the only synchronous remote operation in this
implementation, so be aware that this might be a slow operation.
|
void |
AtomicReferenceCodecTemplate.clear(String name)
Clears the current stored reference.
|
void |
MultiMapCodecTemplate.clear(String name)
Clears the multimap.
|
void |
CacheCodecTemplate.clear(String name)
Clears the contents of the cache, without notifying listeners or CacheWriters.
|
void |
ListCodecTemplate.clear(String name)
Removes all of the elements from this list (optional operation).
|
void |
QueueCodecTemplate.clear(String name)
Removes all of the elements from this collection (optional operation).
|
Object |
SetCodecTemplate.clear(String name)
Removes all of the elements from this set (optional operation).
|
void |
MapCodecTemplate.clear(String name)
This method clears the map and invokes MapStore#deleteAll deleteAll on MapStore which, if connected to a database,
will delete the records from that database.
|
void |
MapCodecTemplate.clearNearCache(String name,
Address target) |
void |
XATransactionalCodecTemplate.clearRemote(Xid xid) |
Object |
XATransactionalCodecTemplate.collectTransactions() |
void |
XATransactionalCodecTemplate.commit(String transactionId,
boolean onePhase) |
void |
TransactionalCodecTemplate.commit(String transactionId,
long threadId) |
Object |
ListCodecTemplate.compareAndRemoveAll(String name,
List<Data> values)
Removes from this list all of its elements that are contained in the specified collection (optional operation).
|
Object |
QueueCodecTemplate.compareAndRemoveAll(String name,
List<Data> dataList)
Removes all of this collection's elements that are also contained in the specified collection (optional operation).
|
Object |
SetCodecTemplate.compareAndRemoveAll(String name,
List<Data> values)
Removes from this set all of its elements that are contained in the specified collection (optional operation).
|
Object |
ListCodecTemplate.compareAndRetainAll(String name,
List<Data> values)
Retains only the elements in this list that are contained in the specified collection (optional operation).
|
Object |
QueueCodecTemplate.compareAndRetainAll(String name,
List<Data> dataList)
Retains only the elements in this collection that are contained in the specified collection (optional operation).
|
Object |
SetCodecTemplate.compareAndRetainAll(String name,
List<Data> values)
Retains only the elements in this set that are contained in the specified collection (optional operation).
|
Object |
AtomicReferenceCodecTemplate.compareAndSet(String name,
Data expected,
Data updated)
Atomically sets the value to the given updated value only if the current value the expected value.
|
Object |
AtomicLongCodecTemplate.compareAndSet(String name,
long expected,
long updated)
Atomically sets the value to the given updated value only if the current value the expected value.
|
Object |
AtomicReferenceCodecTemplate.contains(String name,
Data expected)
Checks if the reference contains the value.
|
Object |
ListCodecTemplate.contains(String name,
Data value)
Returns true if this list contains the specified element.
|
Object |
QueueCodecTemplate.contains(String name,
Data value)
Returns true if this queue contains the specified element.
|
Object |
SetCodecTemplate.contains(String name,
Data value)
Returns true if this set contains the specified element.
|
Object |
ListCodecTemplate.containsAll(String name,
List<Data> values)
Returns true if this list contains all of the elements of the specified collection.
|
Object |
QueueCodecTemplate.containsAll(String name,
List<Data> dataList)
Return true if this collection contains all of the elements in the specified collection.
|
Object |
SetCodecTemplate.containsAll(String name,
List<Data> items)
Returns true if this set contains all of the elements of the specified collection.
|
Object |
MultiMapCodecTemplate.containsEntry(String name,
Data key,
Data value,
long threadId)
Returns whether the multimap contains the given key-value pair.
|
Object |
ReplicatedMapCodecTemplate.containsKey(String name,
Data key)
Returns true if this map contains a mapping for the specified key.
|
Object |
CacheCodecTemplate.containsKey(String name,
Data key)
Determines if the Cache contains an entry for the specified key.
|
Object |
MultiMapCodecTemplate.containsKey(String name,
Data key,
long threadId)
Returns whether the multimap contains an entry with the key.
|
Object |
MapCodecTemplate.containsKey(String name,
Data key,
long threadId)
Returns true if this map contains a mapping for the specified key.
|
Object |
TransactionalMapCodecTemplate.containsKey(String name,
String txnId,
long threadId,
Data key)
Returns true if this map contains an entry for the specified key.
|
Object |
ReplicatedMapCodecTemplate.containsValue(String name,
Data value)
Returns true if this map maps one or more keys to the specified value.
|
Object |
MultiMapCodecTemplate.containsValue(String name,
Data value)
Returns whether the multimap contains an entry with the value.
|
Object |
MapCodecTemplate.containsValue(String name,
Data value)
Returns true if this map maps one or more keys to the specified value.This operation will probably require time
linear in the map size for most implementations of the Map interface.
|
void |
CountdownLatchCodecTemplate.countDown(String name)
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
|
Object |
TransactionalCodecTemplate.create(long timeout,
int durability,
int transactionType,
long threadId) |
Object |
XATransactionalCodecTemplate.create(Xid xid,
long timeout) |
Object |
CacheCodecTemplate.createConfig(Data cacheConfig,
boolean createAlsoOnOthers) |
void |
ClientMessageTemplate.createProxy(String name,
String serviceName,
Address target) |
Object |
AtomicLongCodecTemplate.decrementAndGet(String name)
Atomically decrements the current value by one.
|
void |
MapCodecTemplate.delete(String name,
Data key,
long threadId)
Removes the mapping for a key from this map if it is present.Unlike remove(Object), this operation does not return
the removed value, which avoids the serialization cost of the returned value.If the removed value will not be used,
a delete operation is preferred over a remove operation for better performance.
|
void |
TransactionalMapCodecTemplate.delete(String name,
String txnId,
long threadId,
Data key)
Removes the mapping for a key from this map if it is present.
|
void |
CacheCodecTemplate.destroy(String name)
Closes the cache.
|
Object |
EnterpriseMapCodecTemplate.destroyCache(String mapName,
String cacheName) |
void |
ClientMessageTemplate.destroyProxy(String name,
String serviceName) |
Object |
SemaphoreCodecTemplate.drainPermits(String name)
Acquires and returns all permits that are immediately available.
|
Object |
QueueCodecTemplate.drainTo(String name)
Removes all available elements from this queue and adds them to the given collection.
|
Object |
QueueCodecTemplate.drainToMaxSize(String name,
int maxSize)
Removes at most the given number of available elements from this queue and adds them to the given collection.
|
Object |
MapCodecTemplate.entriesWithPagingPredicate(String name,
Data predicate) |
Object |
MapCodecTemplate.entriesWithPredicate(String name,
Data predicate)
Queries the map based on the specified predicate and returns the matching entries.Specified predicate
runs on all members in parallel.
|
Object |
CacheCodecTemplate.entryProcessor(String name,
Data key,
Data entryProcessor,
List<Data> arguments,
int completionId) |
Object |
ReplicatedMapCodecTemplate.entrySet(String name) |
Object |
MultiMapCodecTemplate.entrySet(String name)
Returns the set of key-value pairs in the multimap.The collection is NOT backed by the map, so changes to the map
are NOT reflected in the collection, and vice-versa
|
Object |
MapCodecTemplate.entrySet(String name)
Returns a Set clone of the mappings contained in this map.
|
Object |
MapCodecTemplate.evict(String name,
Data key,
long threadId)
Evicts the specified key from this map.
|
void |
MapCodecTemplate.evictAll(String name)
Evicts all keys from this map except the locked ones.
|
Object |
MapCodecTemplate.executeOnAllKeys(String name,
Data entryProcessor)
Applies the user defined EntryProcessor to the all entries in the map.Returns the results mapped by each key in the map.
|
Object |
MapCodecTemplate.executeOnKey(String name,
Data entryProcessor,
Data key,
long threadId)
Applies the user defined EntryProcessor to the entry mapped by the key.
|
Object |
MapCodecTemplate.executeOnKeys(String name,
Data entryProcessor,
List<Data> keys)
Applies the user defined EntryProcessor to the entries mapped by the collection of keys.The results mapped by
each key in the collection.
|
Object |
MapCodecTemplate.executeWithPredicate(String name,
Data entryProcessor,
Data predicate)
Applies the user defined EntryProcessor to the entries in the map which satisfies provided predicate.
|
void |
XATransactionalCodecTemplate.finalize(Xid xid,
boolean isCommit) |
void |
MapCodecTemplate.flush(String name)
If this map has a MapStore, this method flushes all the local dirty entries by calling MapStore.storeAll()
and/or MapStore.deleteAll().
|
void |
LockCodecTemplate.forceUnlock(String name)
Releases the lock regardless of the lock owner.
|
void |
MultiMapCodecTemplate.forceUnlock(String name,
Data key)
Releases the lock for the specified key regardless of the lock owner.
|
void |
MapCodecTemplate.forceUnlock(String name,
Data key)
Releases the lock for the specified key regardless of the lock owner.It always successfully unlocks the key,
never blocks,and returns immediately.
|
Object |
MapReduceCodecTemplate.forCustom(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
Data keyValueSource,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forList(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String listName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forMap(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String mapName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forMultiMap(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String multiMapName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forSet(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String setName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
AtomicReferenceCodecTemplate.get(String name)
Gets the current value.
|
Object |
AtomicLongCodecTemplate.get(String name)
Gets the current value.
|
Object |
ReplicatedMapCodecTemplate.get(String name,
Data key)
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
|
Object |
CacheCodecTemplate.get(String name,
Data key,
Data expiryPolicy)
Retrieves the mapped value of the given key using a custom javax.cache.expiry.ExpiryPolicy.
|
Object |
MultiMapCodecTemplate.get(String name,
Data key,
long threadId)
Returns the collection of values associated with the key.
|
Object |
MapCodecTemplate.get(String name,
Data key,
long threadId)
This method returns a clone of the original value, so modifying the returned value does not change the actual
value in the map.
|
Object |
ListCodecTemplate.get(String name,
int index)
Returns the element at the specified position in this list
|
Object |
TransactionalMapCodecTemplate.get(String name,
String txnId,
long threadId,
Data key)
Returns the value for the specified key, or null if this map does not contain this key.
|
Object |
TransactionalMultiMapCodecTemplate.get(String name,
String txnId,
long threadId,
Data key)
Returns the collection of values associated with the key.
|
Object |
ListCodecTemplate.getAll(String name)
Return the all elements of this collection
|
Object |
SetCodecTemplate.getAll(String name)
Return the all elements of this collection
|
Object |
MapCodecTemplate.getAll(String name,
List<Data> keys)
Returns the entries for the given keys.
|
Object |
CacheCodecTemplate.getAll(String name,
List<Data> keys,
Data expiryPolicy)
Gets a collection of entries from the cache with custom expiry policy, returning them as Map of the values
associated with the set of keys requested.
|
Object |
AtomicLongCodecTemplate.getAndAdd(String name,
long delta)
Atomically adds the given value to the current value.
|
Object |
AtomicReferenceCodecTemplate.getAndAlter(String name,
Data function)
Alters the currently stored reference by applying a function on it on and gets the old value.
|
Object |
AtomicLongCodecTemplate.getAndAlter(String name,
Data function)
Alters the currently stored value by applying a function on it on and gets the old value.
|
Object |
AtomicLongCodecTemplate.getAndIncrement(String name)
Atomically increments the current value by one.
|
Object |
CacheCodecTemplate.getAndRemove(String name,
Data key,
int completionId)
Atomically removes the entry for a key only if currently mapped to some value.
|
Object |
CacheCodecTemplate.getAndReplace(String name,
Data key,
Data value,
Data expiryPolicy,
int completionId)
Atomically replaces the assigned value of the given key by the specified value using a custom
javax.cache.expiry.ExpiryPolicy and returns the previously assigned value.
|
Object |
AtomicReferenceCodecTemplate.getAndSet(String name,
Data newValue)
Gets the old value and sets the new value.
|
Object |
AtomicLongCodecTemplate.getAndSet(String name,
long newValue)
Atomically sets the given value and returns the old value.
|
Object |
CacheCodecTemplate.getConfig(String name,
String simpleName) |
Object |
CountdownLatchCodecTemplate.getCount(String name)
Returns the current count.
|
Object |
ClientMessageTemplate.getDistributedObjects() |
Object |
MapCodecTemplate.getEntryView(String name,
Data key,
long threadId)
Returns the EntryView for the specified key.
|
Object |
TransactionalMapCodecTemplate.getForUpdate(String name,
String txnId,
long threadId,
Data key)
Locks the key and then gets and returns the value to which the specified key is mapped.
|
Object |
LockCodecTemplate.getLockCount(String name)
Returns re-entrant lock hold count, regardless of lock ownership.
|
Object |
ClientMessageTemplate.getPartitions() |
Object |
LockCodecTemplate.getRemainingLeaseTime(String name)
Returns remaining lease time in milliseconds.
|
Object |
RingbufferCodecTemplate.headSequence(String name)
Returns the sequence of the head.
|
Object |
AtomicLongCodecTemplate.incrementAndGet(String name)
Atomically increments the current value by one.
|
Object |
ListCodecTemplate.indexOf(String name,
Data value)
Returns the index of the first occurrence of the specified element in this list, or -1 if this list does not
contain the element.
|
Object |
SemaphoreCodecTemplate.init(String name,
int permits)
Try to initialize this ISemaphore instance with the given permit count
|
Object |
ReplicatedMapCodecTemplate.isEmpty(String name)
Return true if this map contains no key-value mappings
|
Object |
ListCodecTemplate.isEmpty(String name)
Returns true if this list contains no elements
|
Object |
QueueCodecTemplate.isEmpty(String name)
Returns true if this collection contains no elements.
|
Object |
SetCodecTemplate.isEmpty(String name)
Returns true if this set contains no elements.
|
Object |
MapCodecTemplate.isEmpty(String name)
Returns true if this map contains no key-value mappings.
|
Object |
TransactionalMapCodecTemplate.isEmpty(String name,
String txnId,
long threadId)
Returns true if this map contains no entries.
|
Object |
LockCodecTemplate.isLocked(String name)
Returns whether this lock is locked or not.
|
Object |
MultiMapCodecTemplate.isLocked(String name,
Data key)
Checks the lock for the specified key.
|
Object |
MapCodecTemplate.isLocked(String name,
Data key)
Checks the lock for the specified key.If the lock is acquired then returns true, else returns false.
|
Object |
LockCodecTemplate.isLockedByCurrentThread(String name,
long threadId)
Returns whether this lock is locked by current thread or not.
|
Object |
AtomicReferenceCodecTemplate.isNull(String name)
Checks if the stored reference is null.
|
Object |
ExecutorServiceCodecTemplate.isShutdown(String name)
Returns true if this executor has been shut down.
|
Object |
CacheCodecTemplate.iterate(String name,
int partitionId,
int tableIndex,
int batch)
The ordering of iteration over entries is undefined.
|
Object |
ListCodecTemplate.iterator(String name)
Returns an iterator over the elements in this list in proper sequence.
|
Object |
QueueCodecTemplate.iterator(String name)
Returns an iterator over the elements in this collection.
|
Object |
MapReduceCodecTemplate.jobProcessInformation(String name,
String jobId) |
Object |
ReplicatedMapCodecTemplate.keySet(String name)
Returns a lazy Set view of the key contained in this map.
|
Object |
MultiMapCodecTemplate.keySet(String name)
Returns the set of keys in the multimap.The collection is NOT backed by the map, so changes to the map are NOT
reflected in the collection, and vice-versa.
|
Object |
MapCodecTemplate.keySet(String name)
Returns a set clone of the keys contained in this map.
|
Object |
TransactionalMapCodecTemplate.keySet(String name,
String txnId,
long threadId)
Returns a set clone of the keys contained in this map.
|
Object |
MapCodecTemplate.keySetWithPagingPredicate(String name,
Data predicate) |
Object |
MapCodecTemplate.keySetWithPredicate(String name,
Data predicate)
Queries the map based on the specified predicate and returns the keys of matching entries.
|
Object |
TransactionalMapCodecTemplate.keySetWithPredicate(String name,
String txnId,
long threadId,
Data predicate)
Queries the map based on the specified predicate and returns the keys of matching entries.
|
Object |
ListCodecTemplate.lastIndexOf(String name,
Data value)
Returns the index of the last occurrence of the specified element in this list, or -1 if this list does not
contain the element.
|
void |
CacheCodecTemplate.listenerRegistration(String name,
Data listenerConfig,
boolean shouldRegister,
Address address) |
Object |
ListCodecTemplate.listIterator(String name,
int index)
Returns a list iterator over the elements in this list (in proper sequence), starting at the specified position
in the list.
|
void |
MapCodecTemplate.loadAll(String name,
boolean replaceExistingValues)
Loads all keys into the store.
|
void |
CacheCodecTemplate.loadAll(String name,
List<Data> keys,
boolean replaceExistingValues) |
void |
MapCodecTemplate.loadGivenKeys(String name,
List<Data> keys,
boolean replaceExistingValues)
Loads the given keys.
|
void |
MultiMapCodecTemplate.lock(String name,
Data key,
long threadId,
long ttl)
Acquires the lock for the specified key for the specified lease time.
|
void |
MapCodecTemplate.lock(String name,
Data key,
long threadId,
long ttl)
Acquires the lock for the specified lease time.After lease time, lock will be released.If the lock is not
available then the current thread becomes disabled for thread scheduling purposes and lies dormant until the lock
has been acquired.
|
void |
LockCodecTemplate.lock(String name,
long leaseTime,
long threadId)
Acquires the lock for the specified lease time.After lease time, lock will be released.If the lock is not
available then the current thread becomes disabled for thread scheduling purposes and lies dormant until the lock
has been acquired.
|
Object |
EnterpriseMapCodecTemplate.madePublishable(String mapName,
String cacheName) |
void |
CacheCodecTemplate.managementConfig(String name,
boolean isStat,
boolean enabled,
Address address) |
Object |
QueueCodecTemplate.offer(String name,
Data value,
long timeoutMillis)
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to
become available.
|
Object |
TransactionalQueueCodecTemplate.offer(String name,
String txnId,
long threadId,
Data item,
long timeout)
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to
become available.
|
Object |
QueueCodecTemplate.peek(String name)
Retrieves, but does not remove, the head of this queue, or returns null if this queue is empty.
|
Object |
TransactionalQueueCodecTemplate.peek(String name,
String txnId,
long threadId,
long timeout)
Retrieves, but does not remove, the head of this queue, or returns null if this queue is empty.
|
void |
ClientMessageTemplate.ping() |
Object |
QueueCodecTemplate.poll(String name,
long timeoutMillis)
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element
to become available.
|
Object |
TransactionalQueueCodecTemplate.poll(String name,
String txnId,
long threadId,
long timeout)
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element
to become available.
|
void |
XATransactionalCodecTemplate.prepare(String transactionId) |
void |
TopicCodecTemplate.publish(String name,
Data message)
Publishes the message to all subscribers of this topic
|
Object |
EnterpriseMapCodecTemplate.publisherCreate(String mapName,
String cacheName,
Data predicate,
int batchSize,
int bufferSize,
long delaySeconds,
boolean populate,
boolean coalesce) |
Object |
EnterpriseMapCodecTemplate.publisherCreateWithValue(String mapName,
String cacheName,
Data predicate,
int batchSize,
int bufferSize,
long delaySeconds,
boolean populate,
boolean coalesce) |
void |
QueueCodecTemplate.put(String name,
Data value)
Inserts the specified element into this queue, waiting if necessary for space to become available.
|
Object |
CacheCodecTemplate.put(String name,
Data key,
Data value,
Data expiryPolicy,
boolean get,
int completionId) |
Object |
ReplicatedMapCodecTemplate.put(String name,
Data key,
Data value,
long ttl)
Associates a given value to the specified key and replicates it to the cluster.
|
Object |
MultiMapCodecTemplate.put(String name,
Data key,
Data value,
long threadId)
Stores a key-value pair in the multimap.
|
Object |
MapCodecTemplate.put(String name,
Data key,
Data value,
long threadId,
long ttl)
Puts an entry into this map with a given ttl (time to live) value.Entry will expire and get evicted after the ttl
If ttl is 0, then the entry lives forever.This method returns a clone of the previous value, not the original
(identically equal) value previously put into the map.Time resolution for TTL is seconds.
|
Object |
TransactionalMultiMapCodecTemplate.put(String name,
String txnId,
long threadId,
Data key,
Data value)
Stores a key-value pair in the multimap.
|
Object |
TransactionalMapCodecTemplate.put(String name,
String txnId,
long threadId,
Data key,
Data value,
long ttl)
Associates the specified value with the specified key in this map.
|
void |
ReplicatedMapCodecTemplate.putAll(String name,
List<Map.Entry<Data,Data>> entries)
Copies all of the mappings from the specified map to this map (optional operation).
|
void |
CacheCodecTemplate.putAll(String name,
List<Map.Entry<Data,Data>> entries,
Data expiryPolicy,
int completionId) |
void |
MapCodecTemplate.putAll(String name,
Map<Data,Data> entries)
Copies all of the mappings from the specified map to this map (optional operation).The effect of this call is
equivalent to that of calling put(Object,Object) put(k, v) on this map once for each mapping from key k to value
v in the specified map.The behavior of this operation is undefined if the specified map is modified while the
operation is in progress.
|
Object |
CacheCodecTemplate.putIfAbsent(String name,
Data key,
Data value,
Data expiryPolicy,
int completionId)
Associates the specified key with the given value if and only if there is not yet a mapping defined for the
specified key.
|
Object |
MapCodecTemplate.putIfAbsent(String name,
Data key,
Data value,
long threadId,
long ttl)
Puts an entry into this map with a given ttl (time to live) value if the specified key is not already associated
with a value.
|
Object |
TransactionalMapCodecTemplate.putIfAbsent(String name,
String txnId,
long threadId,
Data key,
Data value)
If the specified key is not already associated with a value, associate it with the given value.
|
void |
MapCodecTemplate.putTransient(String name,
Data key,
Data value,
long threadId,
long ttl)
Same as put except that MapStore, if defined, will not be called to store/persist the entry.
|
Object |
RingbufferCodecTemplate.readMany(String name,
long startSequence,
int minCount,
int maxCount,
Data filter)
Reads a batch of items from the Ringbuffer.
|
Object |
RingbufferCodecTemplate.readOne(String name,
long sequence)
Reads one item from the Ringbuffer.
|
void |
SemaphoreCodecTemplate.reducePermits(String name,
int reduction)
Shrinks the number of available permits by the indicated reduction.
|
void |
SemaphoreCodecTemplate.release(String name,
int permits)
Releases the given number of permits, increasing the number of available permits by that amount.
|
Object |
RingbufferCodecTemplate.remainingCapacity(String name)
Returns the remaining capacity of the ringbuffer.
|
Object |
QueueCodecTemplate.remainingCapacity(String name)
Returns the number of additional elements that this queue can ideally (in the absence of memory or resource
constraints) accept without blocking, or Integer.MAX_VALUE if there is no intrinsic limit.
|
Object |
ReplicatedMapCodecTemplate.remove(String name,
Data key)
Removes the mapping for a key from this map if it is present (optional operation).
|
Object |
ListCodecTemplate.remove(String name,
Data value)
Removes the first occurrence of the specified element from this list, if it is present (optional operation).
|
Object |
QueueCodecTemplate.remove(String name,
Data value)
Retrieves and removes the head of this queue.
|
Object |
SetCodecTemplate.remove(String name,
Data value)
Removes the specified element from this set if it is present (optional operation).
|
Object |
CacheCodecTemplate.remove(String name,
Data key,
Data currentValue,
int completionId)
Atomically removes the mapping for a key only if currently mapped to the given value.
|
Object |
MultiMapCodecTemplate.remove(String name,
Data key,
long threadId)
Removes the given key value pair from the multimap.
|
Object |
MapCodecTemplate.remove(String name,
Data key,
long threadId)
Removes the mapping for a key from this map if it is present (optional operation).
|
Object |
TransactionalSetCodecTemplate.remove(String name,
String txnId,
long threadId,
Data item)
Remove item from transactional set.
|
Object |
TransactionalMapCodecTemplate.remove(String name,
String txnId,
long threadId,
Data key)
Removes the mapping for a key from this map if it is present.
|
Object |
TransactionalMultiMapCodecTemplate.remove(String name,
String txnId,
long threadId,
Data key)
Removes the given key value pair from the multimap.
|
Object |
TransactionalListCodecTemplate.remove(String name,
String txnId,
long threadId,
Data item)
Remove item from the transactional list
|
void |
CacheCodecTemplate.removeAll(String name,
int completionId)
Removes all of the mappings from this cache.
|
void |
CacheCodecTemplate.removeAllKeys(String name,
List<Data> keys,
int completionId)
Removes entries for the specified keys.
|
void |
ClientMessageTemplate.removeAllListeners() |
Object |
ClientMessageTemplate.removeDistributedObjectListener(String registrationId) |
Object |
MultiMapCodecTemplate.removeEntry(String name,
Data key,
Data value,
long threadId)
Removes all the entries with the given key.
|
Object |
TransactionalMultiMapCodecTemplate.removeEntry(String name,
String txnId,
long threadId,
Data key,
Data value)
Removes all the entries associated with the given key.
|
Object |
ReplicatedMapCodecTemplate.removeEntryListener(String name,
String registrationId)
Removes the specified entry listener.
|
Object |
MultiMapCodecTemplate.removeEntryListener(String name,
String registrationId)
Removes the specified entry listener.
|
Object |
CacheCodecTemplate.removeEntryListener(String name,
String registrationId) |
Object |
MapCodecTemplate.removeEntryListener(String name,
String registrationId)
Removes the specified entry listener.
|
Object |
MapCodecTemplate.removeIfSame(String name,
Data key,
Data value,
long threadId)
Removes the mapping for a key from this map if existing value equal to the this value
|
Object |
TransactionalMapCodecTemplate.removeIfSame(String name,
String txnId,
long threadId,
Data key,
Data value)
Removes the entry for a key only if currently mapped to a given value.
|
Object |
MapCodecTemplate.removeInterceptor(String name,
String id)
Removes the given interceptor for this map so it will not intercept operations anymore.
|
Object |
CacheCodecTemplate.removeInvalidationListener(String name,
String registrationId) |
Object |
ListCodecTemplate.removeListener(String name,
String registrationId)
Removes the specified item listener.
|
Object |
QueueCodecTemplate.removeListener(String name,
String registrationId)
Removes the specified item listener.Returns silently if the specified listener was not added before.
|
Object |
SetCodecTemplate.removeListener(String name,
String registrationId)
Removes the specified item listener.
|
Object |
TopicCodecTemplate.removeMessageListener(String name,
String registrationId)
Stops receiving messages for the given message listener.If the given listener already removed, this method does nothing.
|
Object |
ClientMessageTemplate.removePartitionLostListener(String registrationId) |
Object |
CacheCodecTemplate.removePartitionLostListener(String name,
String registrationId)
Removes the specified cache partition lost listener.
|
Object |
MapCodecTemplate.removePartitionLostListener(String name,
String registrationId)
Removes the specified map partition lost listener.
|
Object |
ListCodecTemplate.removeWithIndex(String name,
int index)
Removes the element at the specified position in this list (optional operation).
|
Object |
CacheCodecTemplate.replace(String name,
Data key,
Data oldValue,
Data newValue,
Data expiryPolicy,
int completionId)
Atomically 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 javax.cache.expiry.ExpiryPolicy
If the cache is configured for write-through operation mode, the underlying configured
javax.cache.integration.CacheWriter might be called to store the value of the key to any kind of external resource.
|
Object |
MapCodecTemplate.replace(String name,
Data key,
Data value,
long threadId)
Replaces the entry for a key only if currently mapped to a given value.
|
Object |
TransactionalMapCodecTemplate.replace(String name,
String txnId,
long threadId,
Data key,
Data value)
Replaces the entry for a key only if it is currently mapped to some value.
|
Object |
MapCodecTemplate.replaceIfSame(String name,
Data key,
Data testValue,
Data value,
long threadId)
Replaces the the entry for a key only if existing values equal to the testValue
|
Object |
TransactionalMapCodecTemplate.replaceIfSame(String name,
String txnId,
long threadId,
Data key,
Data oldValue,
Data newValue)
Replaces the entry for a key only if currently mapped to a given value.
|
void |
XATransactionalCodecTemplate.rollback(String transactionId) |
void |
TransactionalCodecTemplate.rollback(String transactionId,
long threadId) |
void |
AtomicReferenceCodecTemplate.set(String name,
Data newValue)
Atomically sets the given value.
|
void |
MapCodecTemplate.set(String name,
Data key,
Data value,
long threadId,
long ttl)
Puts an entry into this map with a given ttl (time to live) value.Entry will expire and get evicted after the ttl
If ttl is 0, then the entry lives forever.
|
Object |
ListCodecTemplate.set(String name,
int index,
Data value)
The element previously at the specified position
|
void |
AtomicLongCodecTemplate.set(String name,
long newValue)
Atomically sets the given value.
|
void |
TransactionalMapCodecTemplate.set(String name,
String txnId,
long threadId,
Data key,
Data value)
Associates the specified value with the specified key in this map.
|
Object |
AtomicReferenceCodecTemplate.setAndGet(String name,
Data newValue)
Sets and gets the value.
|
Object |
EnterpriseMapCodecTemplate.setReadCursor(String mapName,
String cacheName,
long sequence)
This method can be used to recover from a possible event loss situation.
|
void |
ExecutorServiceCodecTemplate.shutdown(String name)
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
|
void |
ConditionCodecTemplate.signal(String name,
long threadId,
String lockName)
If any threads are waiting on this condition then one is selected for waking up.That thread must then re-acquire
the lock before returning from await.
|
void |
ConditionCodecTemplate.signalAll(String name,
long threadId,
String lockName)
If any threads are waiting on this condition then they are all woken up.
|
Object |
ReplicatedMapCodecTemplate.size(String name)
Returns the number of key-value mappings in this map.
|
Object |
MultiMapCodecTemplate.size(String name)
Returns the number of key-value pairs in the multimap.
|
Object |
CacheCodecTemplate.size(String name)
Total entry count
|
Object |
RingbufferCodecTemplate.size(String name)
Returns number of items in the ringbuffer.
|
Object |
ListCodecTemplate.size(String name)
Returns the number of elements in this list.
|
Object |
QueueCodecTemplate.size(String name)
Returns the number of elements in this collection.
|
Object |
SetCodecTemplate.size(String name)
Returns the number of elements in this set (its cardinality).
|
Object |
MapCodecTemplate.size(String name)
Returns the number of key-value mappings in this map.
|
Object |
TransactionalSetCodecTemplate.size(String name,
String txnId,
long threadId)
Returns the size of the set.
|
Object |
TransactionalMapCodecTemplate.size(String name,
String txnId,
long threadId)
Returns the number of entries in this map.
|
Object |
TransactionalMultiMapCodecTemplate.size(String name,
String txnId,
long threadId)
Returns the number of key-value pairs in the multimap.
|
Object |
TransactionalListCodecTemplate.size(String name,
String txnId,
long threadId)
Returns the size of the list
|
Object |
TransactionalQueueCodecTemplate.size(String name,
String txnId,
long threadId)
Returns the number of elements in this collection.If this collection contains more than Integer.MAX_VALUE
elements, returns Integer.MAX_VALUE.
|
Object |
ListCodecTemplate.sub(String name,
int from,
int to)
Returns a view of the portion of this list between the specified from, inclusive, and to, exclusive.(If from and
to are equal, the returned list is empty.) The returned list is backed by this list, so non-structural changes in
the returned list are reflected in this list, and vice-versa.
|
Object |
ExecutorServiceCodecTemplate.submitToAddress(String name,
String uuid,
Data callable,
Address address) |
Object |
MapCodecTemplate.submitToKey(String name,
Data entryProcessor,
Data key,
long threadId)
Applies the user defined EntryProcessor to the entry mapped by the key.
|
Object |
ExecutorServiceCodecTemplate.submitToPartition(String name,
String uuid,
Data callable,
int partitionId) |
Object |
RingbufferCodecTemplate.tailSequence(String name)
Returns the sequence of the tail.
|
Object |
QueueCodecTemplate.take(String name)
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
|
Object |
TransactionalQueueCodecTemplate.take(String name,
String txnId,
long threadId)
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
|
Object |
SemaphoreCodecTemplate.tryAcquire(String name,
int permits,
long timeout)
Acquires the given number of permits, if they are available, and returns immediately, with the value true,
reducing the number of available permits by the given amount.
|
Object |
MultiMapCodecTemplate.tryLock(String name,
Data key,
long threadId,
long lease,
long timeout)
Tries to acquire the lock for the specified key for the specified lease time.
|
Object |
MapCodecTemplate.tryLock(String name,
Data key,
long threadId,
long lease,
long timeout)
Tries to acquire the lock for the specified key for the specified lease time.After lease time, the lock will be
released.If the lock is not available, then the current thread becomes disabled for thread scheduling
purposes and lies dormant until one of two things happens the lock is acquired by the current thread, or
the specified waiting time elapses.
|
Object |
LockCodecTemplate.tryLock(String name,
long threadId,
long lease,
long timeout)
Tries to acquire the lock for the specified lease time.After lease time, the lock will be released.
|
Object |
MapCodecTemplate.tryPut(String name,
Data key,
Data value,
long threadId,
long timeout)
Tries to put the given key and value into this map within a specified timeout value.
|
Object |
MapCodecTemplate.tryRemove(String name,
Data key,
long threadId,
long timeout)
Tries to remove the entry with the given key from this map within the specified timeout value.
|
Object |
CountdownLatchCodecTemplate.trySetCount(String name,
int count)
Sets the count to the given value if the current count is zero.
|
void |
MultiMapCodecTemplate.unlock(String name,
Data key,
long threadId)
Releases the lock for the specified key regardless of the lock owner.
|
void |
MapCodecTemplate.unlock(String name,
Data key,
long threadId)
Releases the lock for the specified key.
|
void |
LockCodecTemplate.unlock(String name,
long threadId)
Releases the lock.
|
Object |
MultiMapCodecTemplate.valueCount(String name,
Data key,
long threadId)
Returns the number of values that match the given key in the multimap.
|
Object |
TransactionalMultiMapCodecTemplate.valueCount(String name,
String txnId,
long threadId,
Data key)
Returns the number of values matching the given key in the multimap.
|
Object |
ReplicatedMapCodecTemplate.values(String name) |
Object |
MultiMapCodecTemplate.values(String name)
Returns the collection of values in the multimap.The collection is NOT backed by the map, so changes to the map
are NOT reflected in the collection, and vice-versa.
|
Object |
MapCodecTemplate.values(String name)
Returns a collection clone of the values contained in this map.
|
Object |
TransactionalMapCodecTemplate.values(String name,
String txnId,
long threadId)
Returns a collection clone of the values contained in this map.
|
Object |
MapCodecTemplate.valuesWithPagingPredicate(String name,
Data predicate)
Queries the map based on the specified predicate and returns the values of matching entries.
|
Object |
MapCodecTemplate.valuesWithPredicate(String name,
Data predicate)
Queries the map based on the specified predicate and returns the values of matching entries.Specified predicate
runs on all members in parallel.
|
Object |
TransactionalMapCodecTemplate.valuesWithPredicate(String name,
String txnId,
long threadId,
Data predicate)
Queries the map based on the specified predicate and returns the values of matching entries.Specified predicate
runs on all members in parallel.
|
Copyright © 2016 Hazelcast, Inc.. All Rights Reserved.